prompt
large_stringlengths
70
991k
completion
large_stringlengths
0
1.02k
<|file_name|>simclock.go<|end_file_name|><|fim▁begin|>// Copyright 2018 The go-ethereum Authors // This file is part of the go-ethereum library. // // The go-ethereum library is free software: you can redistribute it and/or modify // it under the terms of the GNU Lesser General Public License as published by // the Free Software Foundation, either version 3 of the License, or // (at your option) any later version. // // The go-ethereum library is distributed in the hope that it will be useful, // but WITHOUT ANY WARRANTY; without even the implied warranty of // MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the // GNU Lesser General Public License for more details. // // You should have received a copy of the GNU Lesser General Public License // along with the go-ethereum library. If not, see <http://www.gnu.org/licenses/>. package mclock import ( "container/heap" "sync" "time" ) // Simulated implements a virtual Clock for reproducible time-sensitive tests. It // simulates a scheduler on a virtual timescale where actual processing takes zero time. // // The virtual clock doesn't advance on its own, call Run to advance it and execute timers. // Since there is no way to influence the Go scheduler, testing timeout behaviour involving // goroutines needs special care. A good way to test such timeouts is as follows: First // perform the action that is supposed to time out. Ensure that the timer you want to test // is created. Then run the clock until after the timeout. Finally observe the effect of // the timeout using a channel or semaphore. type Simulated struct { now AbsTime scheduled simTimerHeap mu sync.RWMutex cond *sync.Cond } // simTimer implements ChanTimer on the virtual clock. type simTimer struct { at AbsTime index int // position in s.scheduled s *Simulated do func() ch <-chan AbsTime } func (s *Simulated) init() { if s.cond == nil { s.cond = sync.NewCond(&s.mu) } } // Run moves the clock by the given duration, executing all timers before that duration. func (s *Simulated) Run(d time.Duration) { s.mu.Lock() s.init() end := s.now + AbsTime(d) var do []func() for len(s.scheduled) > 0 && s.scheduled[0].at <= end { ev := heap.Pop(&s.scheduled).(*simTimer) do = append(do, ev.do) } s.now = end s.mu.Unlock() for _, fn := range do { fn() } } // ActiveTimers returns the number of timers that haven't fired. func (s *Simulated) ActiveTimers() int { s.mu.RLock() defer s.mu.RUnlock() return len(s.scheduled) } // WaitForTimers waits until the clock has at least n scheduled timers. func (s *Simulated) WaitForTimers(n int) { s.mu.Lock() defer s.mu.Unlock() s.init() for len(s.scheduled) < n { s.cond.Wait() } } // Now returns the current virtual time. func (s *Simulated) Now() AbsTime { s.mu.RLock() defer s.mu.RUnlock() return s.now } // Sleep blocks until the clock has advanced by d. func (s *Simulated) Sleep(d time.Duration) { <-s.After(d) } // NewTimer creates a timer which fires when the clock has advanced by d. func (s *Simulated) NewTimer(d time.Duration) ChanTimer { s.mu.Lock() defer s.mu.Unlock() ch := make(chan AbsTime, 1) var timer *simTimer timer = s.schedule(d, func() { ch <- timer.at }) timer.ch = ch return timer } // After returns a channel which receives the current time after the clock // has advanced by d. func (s *Simulated) After(d time.Duration) <-chan AbsTime { return s.NewTimer(d).C() } // AfterFunc runs fn after the clock has advanced by d. Unlike with the system // clock, fn runs on the goroutine that calls Run. func (s *Simulated) AfterFunc(d time.Duration, fn func()) Timer { s.mu.Lock() defer s.mu.Unlock() return s.schedule(d, fn) } func (s *Simulated) schedule(d time.Duration, fn func()) *simTimer { s.init() at := s.now + AbsTime(d) ev := &simTimer{do: fn, at: at, s: s} heap.Push(&s.scheduled, ev) s.cond.Broadcast() return ev } func (ev *simTimer) Stop() bool { ev.s.mu.Lock() defer ev.s.mu.Unlock() if ev.index < 0 { return false } heap.Remove(&ev.s.scheduled, ev.index) ev.s.cond.Broadcast() ev.index = -1 return true } func (ev *simTimer) Reset(d time.Duration) { if ev.ch == nil { panic("mclock: Reset() on timer created by AfterFunc") }<|fim▁hole|> defer ev.s.mu.Unlock() ev.at = ev.s.now.Add(d) if ev.index < 0 { heap.Push(&ev.s.scheduled, ev) // already expired } else { heap.Fix(&ev.s.scheduled, ev.index) // hasn't fired yet, reschedule } ev.s.cond.Broadcast() } func (ev *simTimer) C() <-chan AbsTime { if ev.ch == nil { panic("mclock: C() on timer created by AfterFunc") } return ev.ch } type simTimerHeap []*simTimer func (h *simTimerHeap) Len() int { return len(*h) } func (h *simTimerHeap) Less(i, j int) bool { return (*h)[i].at < (*h)[j].at } func (h *simTimerHeap) Swap(i, j int) { (*h)[i], (*h)[j] = (*h)[j], (*h)[i] (*h)[i].index = i (*h)[j].index = j } func (h *simTimerHeap) Push(x interface{}) { t := x.(*simTimer) t.index = len(*h) *h = append(*h, t) } func (h *simTimerHeap) Pop() interface{} { end := len(*h) - 1 t := (*h)[end] t.index = -1 (*h)[end] = nil *h = (*h)[:end] return t }<|fim▁end|>
ev.s.mu.Lock()
<|file_name|>OpenNebula.py<|end_file_name|><|fim▁begin|>#! /usr/bin/env python # # IM - Infrastructure Manager # Copyright (C) 2011 - GRyCAP - Universitat Politecnica de Valencia # # This program is free software: you can redistribute it and/or modify # it under the terms of the GNU General Public License as published by # the Free Software Foundation, either version 3 of the License, or # (at your option) any later version. # # This program is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the # GNU General Public License for more details. # # You should have received a copy of the GNU General Public License # along with this program. If not, see <http://www.gnu.org/licenses/>. import sys import unittest sys.path.append(".") sys.path.append("..") from .CloudConn import TestCloudConnectorBase from IM.CloudInfo import CloudInfo from IM.auth import Authentication from radl import radl_parse from IM.VirtualMachine import VirtualMachine from IM.InfrastructureInfo import InfrastructureInfo from IM.connectors.OpenNebula import OpenNebulaCloudConnector from mock import patch, MagicMock, call class TestONEConnector(TestCloudConnectorBase): """ Class to test the IM connectors """ @staticmethod def get_one_cloud(): cloud_info = CloudInfo() cloud_info.type = "OpenNebula" cloud_info.server = "server.com" cloud_info.port = 2633 inf = MagicMock() inf.id = "1" one_cloud = OpenNebulaCloudConnector(cloud_info, inf) return one_cloud @patch('IM.connectors.OpenNebula.ServerProxy') def test_05_getONEVersion(self, server_proxy): one_server = MagicMock() one_server.system.listMethods.return_value = ["one.system.version"] one_server.one.system.version.return_value = (True, "5.2.1", "") server_proxy.return_value = one_server auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() one_cloud.getONEVersion(auth) def test_10_concrete(self): radl_data = """ network net () system test ( cpu.arch='x86_64' and cpu.count>=1 and memory.size>=512m and net_interface.0.connection = 'net' and net_interface.0.dns_name = 'test' and disk.0.os.name = 'linux' and disk.0.image.url = 'one://server.com/1' and disk.0.os.credentials.username = 'user' and disk.0.os.credentials.password = 'pass' )""" radl = radl_parse.parse_radl(radl_data) radl_system = radl.systems[0] auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() concrete = one_cloud.concreteSystem(radl_system, auth) self.assertEqual(len(concrete), 1) self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') @patch('IM.connectors.OpenNebula.OpenNebulaCloudConnector.getONEVersion') @patch('IM.InfrastructureList.InfrastructureList.save_data') def test_20_launch(self, save_data, getONEVersion, server_proxy): radl_data = """ network net1 (provider_id = 'publica' and outbound = 'yes' and outports = '8080,9000:9100' and sg_name= 'test') network net2 () system test ( cpu.arch='x86_64' and cpu.count=1 and memory.size=512m and availability_zone='0' and net_interface.0.connection = 'net1' and net_interface.0.dns_name = 'test' and net_interface.1.connection = 'net2' and instance_tags = 'key=value,key1=value2' and disk.0.os.name = 'linux' and disk.0.image.url = 'one://server.com/1' and disk.0.os.credentials.username = 'user' and disk.1.size=1GB and disk.1.device='hdb' and disk.1.mount_path='/mnt/path' )""" radl = radl_parse.parse_radl(radl_data) radl.check() auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}, {'type': 'InfrastructureManager', 'username': 'user', 'password': 'pass'}]) one_cloud = self.get_one_cloud() getONEVersion.return_value = "4.14.0" one_server = MagicMock() one_server.one.vm.allocate.return_value = (True, "1", 0) one_server.one.vnpool.info.return_value = (True, self.read_file_as_string("files/nets.xml"), 0) one_server.one.secgrouppool.info.return_value = (True, self.read_file_as_string("files/sgs.xml"), 0) one_server.one.secgroup.allocate.return_value = (True, 1, 0) server_proxy.return_value = one_server inf = InfrastructureInfo() inf.auth = auth res = one_cloud.launch(inf, radl, radl, 1, auth) success, _ = res[0] self.assertTrue(success, msg="ERROR: launching a VM.") sg_template = ('NAME = test\nRULE = [ PROTOCOL = TCP, RULE_TYPE = inbound, RANGE = 22:22 ]\n' 'RULE = [ PROTOCOL = TCP, RULE_TYPE = inbound, RANGE = 8080:8080 ]\n' 'RULE = [ PROTOCOL = TCP, RULE_TYPE = inbound, RANGE = 9000:9100 ]\n') self.assertEqual(one_server.one.secgroup.allocate.call_args_list, [call('user:pass', sg_template)]) vm_template = """ NAME = userimage CPU = 1 VCPU = 1 MEMORY = 512 OS = [ ARCH = "x86_64" ] DISK = [ IMAGE_ID = "1" ] DISK = [ SAVE = no, TYPE = fs , FORMAT = ext3, SIZE = 1024, TARGET = hdb ] SCHED_REQUIREMENTS = "CLUSTER_ID=\\"0\\""\n""" self.assertIn(vm_template, one_server.one.vm.allocate.call_args_list[0][0][1]) self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) # Now test an error in allocate one_server.one.vm.allocate.return_value = (False, "Error msg", 0) res = one_cloud.launch(inf, radl, radl, 1, auth) success, msg = res[0] self.assertFalse(success) self.assertEqual(msg, "ERROR: Error msg") @patch('IM.connectors.OpenNebula.ServerProxy') def test_30_updateVMInfo(self, server_proxy): radl_data = """ network net (outbound = 'yes' and provider_id = 'publica') network net1 (provider_id = 'privada') system test ( cpu.arch='x86_64' and cpu.count=1 and memory.size=512m and net_interface.0.connection = 'net' and net_interface.0.dns_name = 'test' and net_interface.1.connection = 'net1' and disk.0.os.name = 'linux' and disk.0.image.url = 'one://server.com/1' and disk.0.os.credentials.username = 'user' and disk.0.os.credentials.password = 'pass' )""" radl = radl_parse.parse_radl(radl_data) radl.check() auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, radl, radl, one_cloud, 1) one_server = MagicMock() one_server.one.vm.info.return_value = (True, self.read_file_as_string("files/vm_info.xml"), 0) server_proxy.return_value = one_server success, vm = one_cloud.updateVMInfo(vm, auth) self.assertEquals(vm.info.systems[0].getValue("net_interface.1.ip"), "10.0.0.01") self.assertEquals(vm.info.systems[0].getValue("net_interface.0.ip"), "158.42.1.1") self.assertTrue(success, msg="ERROR: updating VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') def test_40_stop(self, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, "", "", one_cloud, 1) one_server = MagicMock() one_server.one.vm.action.return_value = (True, "", 0) server_proxy.return_value = one_server success, _ = one_cloud.stop(vm, auth) self.assertTrue(success, msg="ERROR: stopping VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') def test_50_start(self, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, "", "", one_cloud, 1) one_server = MagicMock() one_server.one.vm.action.return_value = (True, "", 0) server_proxy.return_value = one_server success, _ = one_cloud.start(vm, auth) self.assertTrue(success, msg="ERROR: stopping VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') def test_52_reboot(self, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, "", "", one_cloud, 1) one_server = MagicMock() one_server.one.vm.action.return_value = (True, "", 0) server_proxy.return_value = one_server success, _ = one_cloud.reboot(vm, auth) self.assertTrue(success, msg="ERROR: stopping VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') def test_55_alter(self, server_proxy): radl_data = """ network net () system test ( cpu.arch='x86_64' and cpu.count=1 and memory.size=512m and net_interface.0.connection = 'net' and net_interface.0.dns_name = 'test' and disk.0.os.name = 'linux' and disk.0.image.url = 'one://server.com/1' and disk.0.os.credentials.username = 'user' and disk.0.os.credentials.password = 'pass' )""" radl = radl_parse.parse_radl(radl_data) new_radl_data = """ system test ( cpu.count>=2 and memory.size>=2048m and disk.1.size=1GB and disk.1.device='hdc' and disk.1.fstype='ext4' and disk.1.mount_path='/mnt/disk' )""" new_radl = radl_parse.parse_radl(new_radl_data) auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, radl, radl, one_cloud, 1) one_server = MagicMock() one_server.one.vm.action.return_value = (True, "", 0) one_server.one.vm.resize.return_value = (True, "", 0) one_server.one.vm.info.return_value = (True, self.read_file_as_string("files/vm_info_off.xml"), 0) one_server.one.vm.attach.return_value = (True, "", 0) one_server.system.listMethods.return_value = ["one.vm.resize"] server_proxy.return_value = one_server success, _ = one_cloud.alterVM(vm, new_radl, auth) self.assertTrue(success, msg="ERROR: modifying VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') @patch('IM.connectors.OpenNebula.OpenNebulaCloudConnector._get_security_group') def test_60_finalize(self, get_security_group, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() radl_data = """ network net1 (provider_id = 'publica' and outbound = 'yes' and outports = '8080,9000:9100') network net2 () system test ( cpu.arch='x86_64' and cpu.count=1 and memory.size=512m and net_interface.0.connection = 'net1' and net_interface.0.dns_name = 'test' and net_interface.1.connection = 'net2' and disk.0.os.name = 'linux' and disk.0.image.url = 'one://server.com/1' and disk.0.os.credentials.username = 'user' and disk.1.size=1GB and disk.1.device='hdb' and disk.1.mount_path='/mnt/path' )""" radl = radl_parse.parse_radl(radl_data) radl.check() inf = MagicMock() inf.radl = radl vm = VirtualMachine(inf, "1", one_cloud.cloud, radl, radl, one_cloud, 1) one_server = MagicMock() one_server.one.vm.action.return_value = (True, "", 0) server_proxy.return_value = one_server get_security_group.return_value = 101 one_server.one.secgroup.delete.return_value = (True, "", 0) success, _ = one_cloud.finalize(vm, True, auth) self.assertTrue(success, msg="ERROR: finalizing VM info.") self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) @patch('IM.connectors.OpenNebula.ServerProxy') @patch('IM.connectors.OpenNebula.OpenNebulaCloudConnector.getONEVersion') @patch('time.sleep') def test_70_create_snapshot(self, sleep, getONEVersion, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() inf = MagicMock() vm = VirtualMachine(inf, "1", one_cloud.cloud, "", "", one_cloud, 1) getONEVersion.return_value = "5.2.1" one_server = MagicMock() one_server.one.vm.disksaveas.return_value = (True, 1, 0) one_server.one.image.info.return_value = (True, "<IMAGE><STATE>1</STATE></IMAGE>", 0) server_proxy.return_value = one_server success, new_image = one_cloud.create_snapshot(vm, 0, "image_name", True, auth) self.assertTrue(success, msg="ERROR: creating snapshot: %s" % new_image) self.assertEqual(new_image, 'one://server.com/1') self.assertEqual(one_server.one.vm.disksaveas.call_args_list, [call('user:pass', 1, 0, 'image_name', '', -1)]) self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue())<|fim▁hole|> @patch('time.sleep') def test_80_delete_image(self, sleep, getONEVersion, server_proxy): auth = Authentication([{'id': 'one', 'type': 'OpenNebula', 'username': 'user', 'password': 'pass', 'host': 'server.com:2633'}]) one_cloud = self.get_one_cloud() getONEVersion.return_value = "4.12" one_server = MagicMock() one_server.one.image.delete.return_value = (True, "", 0) one_server.one.imagepool.info.return_value = (True, "<IMAGE_POOL><IMAGE><ID>1</ID>" "<NAME>imagename</NAME></IMAGE></IMAGE_POOL>", 0) one_server.one.image.info.return_value = (True, "<IMAGE><STATE>1</STATE></IMAGE>", 0) server_proxy.return_value = one_server success, msg = one_cloud.delete_image('one://server.com/1', auth) self.assertTrue(success, msg="ERROR: deleting image. %s" % msg) self.assertEqual(one_server.one.image.delete.call_args_list, [call('user:pass', 1)]) self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) success, msg = one_cloud.delete_image('one://server.com/imagename', auth) self.assertTrue(success, msg="ERROR: deleting image. %s" % msg) self.assertEqual(one_server.one.image.delete.call_args_list[1], call('user:pass', 1)) self.assertNotIn("ERROR", self.log.getvalue(), msg="ERROR found in log: %s" % self.log.getvalue()) if __name__ == '__main__': unittest.main()<|fim▁end|>
@patch('IM.connectors.OpenNebula.ServerProxy') @patch('IM.connectors.OpenNebula.OpenNebulaCloudConnector.getONEVersion')
<|file_name|>test_list_endpoints.py<|end_file_name|><|fim▁begin|># Copyright (c) 2012 OpenStack, LLC. # # Licensed under the Apache License, Version 2.0 (the "License"); # you may not use this file except in compliance with the License. # You may obtain a copy of the License at # # http://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, # WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or # implied. # See the License for the specific language governing permissions and # limitations under the License. import array import unittest from shutil import rmtree import os from swift.common import ring, ondisk from swift.common.utils import json from swift.common.swob import Request, Response from swift.common.middleware import list_endpoints class FakeApp(object): def __call__(self, env, start_response): return Response(body="FakeApp")(env, start_response) def start_response(*args): pass class TestListEndpoints(unittest.TestCase): def setUp(self): ondisk.HASH_PATH_SUFFIX = 'endcap' ondisk.HASH_PATH_PREFIX = '' self.testdir = os.path.join(os.path.dirname(__file__), 'ring') rmtree(self.testdir, ignore_errors=1) os.mkdir(self.testdir) accountgz = os.path.join(self.testdir, 'account.ring.gz') containergz = os.path.join(self.testdir, 'container.ring.gz') objectgz = os.path.join(self.testdir, 'object.ring.gz') # Let's make the rings slightly different so we can test # that the correct ring is consulted (e.g. we don't consult # the object ring to get nodes for a container) intended_replica2part2dev_id_a = [ array.array('H', [3, 1, 3, 1]), array.array('H', [0, 3, 1, 4]), array.array('H', [1, 4, 0, 3])] intended_replica2part2dev_id_c = [ array.array('H', [4, 3, 0, 1]), array.array('H', [0, 1, 3, 4]), array.array('H', [3, 4, 0, 1])] intended_replica2part2dev_id_o = [ array.array('H', [0, 1, 0, 1]), array.array('H', [0, 1, 0, 1]), array.array('H', [3, 4, 3, 4])] intended_devs = [{'id': 0, 'zone': 0, 'weight': 1.0, 'ip': '10.1.1.1', 'port': 6000, 'device': 'sda1'}, {'id': 1, 'zone': 0, 'weight': 1.0, 'ip': '10.1.1.1', 'port': 6000, 'device': 'sdb1'}, None, {'id': 3, 'zone': 2, 'weight': 1.0, 'ip': '10.1.2.1', 'port': 6000, 'device': 'sdc1'}, {'id': 4, 'zone': 2, 'weight': 1.0, 'ip': '10.1.2.2', 'port': 6000, 'device': 'sdd1'}] intended_part_shift = 30 ring.RingData(intended_replica2part2dev_id_a, intended_devs, intended_part_shift).save(accountgz) ring.RingData(intended_replica2part2dev_id_c, intended_devs, intended_part_shift).save(containergz) ring.RingData(intended_replica2part2dev_id_o, intended_devs, intended_part_shift).save(objectgz) self.app = FakeApp() self.list_endpoints = list_endpoints.filter_factory( {'swift_dir': self.testdir})(self.app) def tearDown(self): rmtree(self.testdir, ignore_errors=1) def test_get_endpoint(self): # Expected results for objects taken from test_ring # Expected results for others computed by manually invoking # ring.get_nodes(). resp = Request.blank('/endpoints/a/c/o1').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(resp.content_type, 'application/json') self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/1/a/c/o1", "http://10.1.2.2:6000/sdd1/1/a/c/o1" ]) # Here, 'o1/' is the object name. resp = Request.blank('/endpoints/a/c/o1/').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/3/a/c/o1/", "http://10.1.2.2:6000/sdd1/3/a/c/o1/" ]) resp = Request.blank('/endpoints/a/c2').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sda1/2/a/c2", "http://10.1.2.1:6000/sdc1/2/a/c2" ]) resp = Request.blank('/endpoints/a1').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.2.1:6000/sdc1/0/a1", "http://10.1.1.1:6000/sda1/0/a1", "http://10.1.1.1:6000/sdb1/0/a1" ]) resp = Request.blank('/endpoints/').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 400) resp = Request.blank('/endpoints/a/c 2').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/3/a/c%202", "http://10.1.2.2:6000/sdd1/3/a/c%202" ]) resp = Request.blank('/endpoints/a/c%202').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/3/a/c%202", "http://10.1.2.2:6000/sdd1/3/a/c%202" ]) resp = Request.blank('/endpoints/ac%20count/con%20tainer/ob%20ject') \ .get_response(self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/3/ac%20count/con%20tainer/ob%20ject", "http://10.1.2.2:6000/sdd1/3/ac%20count/con%20tainer/ob%20ject" ]) resp = Request.blank('/endpoints/a/c/o1', {'REQUEST_METHOD': 'POST'}) \ .get_response(self.list_endpoints) self.assertEquals(resp.status_int, 405) self.assertEquals(resp.status, '405 Method Not Allowed') self.assertEquals(resp.headers['allow'], 'GET') resp = Request.blank('/not-endpoints').get_response( self.list_endpoints) self.assertEquals(resp.status_int, 200) self.assertEquals(resp.status, '200 OK') self.assertEquals(resp.body, 'FakeApp') # test custom path with trailing slash custom_path_le = list_endpoints.filter_factory({ 'swift_dir': self.testdir, 'list_endpoints_path': '/some/another/path/' })(self.app) resp = Request.blank('/some/another/path/a/c/o1') \ .get_response(custom_path_le) self.assertEquals(resp.status_int, 200) self.assertEquals(resp.content_type, 'application/json') self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/1/a/c/o1", "http://10.1.2.2:6000/sdd1/1/a/c/o1"<|fim▁hole|> 'swift_dir': self.testdir, 'list_endpoints_path': '/some/another/path' })(self.app) resp = Request.blank('/some/another/path/a/c/o1') \ .get_response(custom_path_le) self.assertEquals(resp.status_int, 200) self.assertEquals(resp.content_type, 'application/json') self.assertEquals(json.loads(resp.body), [ "http://10.1.1.1:6000/sdb1/1/a/c/o1", "http://10.1.2.2:6000/sdd1/1/a/c/o1" ]) if __name__ == '__main__': unittest.main()<|fim▁end|>
]) # test ustom path without trailing slash custom_path_le = list_endpoints.filter_factory({
<|file_name|>platform_detect.py<|end_file_name|><|fim▁begin|># Copyright (c) 2014 Adafruit Industries # Author: Tony DiCola # Modified by Mauy5043 (2016) # Permission is hereby granted, free of charge, to any person obtaining a copy # of this software and associated documentation files (the "Software"), to deal # in the Software without restriction, including without limitation the rights # to use, copy, modify, merge, publish, distribute, sublicense, and/or sell # copies of the Software, and to permit persons to whom the Software is # furnished to do so, subject to the following conditions: # The above copyright notice and this permission notice shall be included in all # copies or substantial portions of the Software. # THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR # IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, # FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE # AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER<|fim▁hole|># SOFTWARE. # This is a direct copy of what's in the Adafruit Python GPIO library: # https://raw.githubusercontent.com/adafruit/Adafruit_Python_GPIO/master/Adafruit_GPIO/Platform.py # TODO: Add dependency on Adafruit Python GPIO and use its platform detect # functions. import platform import re # Platform identification constants. UNKNOWN = 0 RASPBERRY_PI = 1 BEAGLEBONE_BLACK = 2 def platform_detect(): return BEAGLEBONE_BLACK<|fim▁end|>
# LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, # OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE
<|file_name|>admin.py<|end_file_name|><|fim▁begin|><|fim▁hole|>from django.core.urlresolvers import reverse from vkontakte_api.admin import VkontakteModelAdmin from .models import Album, Video class VideoInline(admin.TabularInline): def image(self, instance): return '<img src="%s" />' % (instance.photo_130,) image.short_description = 'video' image.allow_tags = True model = Video fields = ('title', 'image', 'owner', 'comments_count', 'views_count') readonly_fields = fields extra = False can_delete = False class AlbumAdmin(VkontakteModelAdmin): def image_preview(self, obj): return u'<a href="%s"><img src="%s" height="30" /></a>' % (obj.photo_160, obj.photo_160) image_preview.short_description = u'Картинка' image_preview.allow_tags = True list_display = ('image_preview', 'remote_id', 'title', 'owner', 'videos_count') list_display_links = ('title', 'remote_id',) search_fields = ('title', 'description') inlines = [VideoInline] class VideoAdmin(VkontakteModelAdmin): def image_preview(self, obj): return u'<a href="%s"><img src="%s" height="30" /></a>' % (obj.photo_130, obj.photo_130) image_preview.short_description = u'Картинка' image_preview.allow_tags = True list_display = ('image_preview', 'remote_id', 'owner', 'album', 'title', 'comments_count', 'views_count', 'date') list_display_links = ('remote_id', 'title') list_filter = ('album',) admin.site.register(Album, AlbumAdmin) admin.site.register(Video, VideoAdmin)<|fim▁end|>
# -*- coding: utf-8 -*- from django.contrib import admin
<|file_name|>HotController.js<|end_file_name|><|fim▁begin|>import webpack from "webpack" import { spawn } from "child_process" import appRootDir from "app-root-dir" import path from "path" import { createNotification } from "./util" import HotServerManager from "./HotServerManager" import HotClientManager from "./HotClientManager" <|fim▁hole|>function safeDisposer(manager) { return manager ? manager.dispose() : Promise.resolve() } /* eslint-disable arrow-body-style, no-console */ function createCompiler({ name, start, done }) { try { const webpackConfig = ConfigFactory({ target: name === "server" ? "node" : "web", mode: "development" }) // Offering a special status handling until Webpack offers a proper `done()` callback // See also: https://github.com/webpack/webpack/issues/4243 webpackConfig.plugins.push(new StatusPlugin({ name, start, done })) return webpack(webpackConfig) } catch (error) { createNotification({ title: "development", level: "error", message: "Webpack config is invalid, please check the console for more information.", notify: true }) console.error(error) throw error } } export default class HotController { constructor() { this.hotClientManager = null this.hotServerManager = null this.clientIsBuilding = false this.serverIsBuilding = false this.timeout = 0 const createClientManager = () => { return new Promise((resolve) => { const compiler = createCompiler({ name: "client", start: () => { this.clientIsBuilding = true createNotification({ title: "Hot Client", level: "info", message: "Building new bundle..." }) }, done: () => { this.clientIsBuilding = false createNotification({ title: "Hot Client", level: "info", message: "Bundle is ready.", notify: true }) resolve(compiler) } }) this.hotClientCompiler = compiler this.hotClientManager = new HotClientManager(compiler) }) } const createServerManager = () => { return new Promise((resolve) => { const compiler = createCompiler({ name: "server", start: () => { this.serverIsBuilding = true createNotification({ title: "Hot Server", level: "info", message: "Building new bundle..." }) }, done: () => { this.serverIsBuilding = false createNotification({ title: "Hot Server", level: "info", message: "Bundle is ready.", notify: true }) this.tryStartServer() resolve(compiler) } }) this.compiledServer = path.resolve( appRootDir.get(), compiler.options.output.path, `${Object.keys(compiler.options.entry)[0]}.js`, ) this.hotServerCompiler = compiler this.hotServerManager = new HotServerManager(compiler, this.hotClientCompiler) }) } createClientManager().then(createServerManager).catch((error) => { console.error("Error during build:", error) }) } tryStartServer = () => { if (this.clientIsBuilding) { if (this.serverTryTimeout) { clearTimeout(this.serverTryTimeout) } this.serverTryTimeout = setTimeout(this.tryStartServer, this.timeout) this.timeout += 100 return } this.startServer() this.timeout = 0 } startServer = () => { if (this.server) { this.server.kill() this.server = null createNotification({ title: "Hot Server", level: "info", message: "Restarting server..." }) } const newServer = spawn("node", [ "--inspect", this.compiledServer, "--colors" ], { stdio: [ process.stdin, process.stdout, "pipe" ] }) createNotification({ title: "Hot Server", level: "info", message: "Server running with latest changes.", notify: true }) newServer.stderr.on("data", (data) => { createNotification({ title: "Hot Server", level: "error", message: "Error in server execution, check the console for more info." }) process.stderr.write("\n") process.stderr.write(data) process.stderr.write("\n") }) this.server = newServer } dispose() { // First the hot client server. Then dispose the hot node server. return safeDisposer(this.hotClientManager).then(() => safeDisposer(this.hotServerManager)).catch((error) => { console.error(error) }) } }<|fim▁end|>
import ConfigFactory from "../webpack/ConfigFactory" import StatusPlugin from "../webpack/plugins/Status"
<|file_name|>test_schedule.py<|end_file_name|><|fim▁begin|># This file is part of wger Workout Manager. # # wger Workout Manager is free software: you can redistribute it and/or modify # it under the terms of the GNU Affero General Public License as published by # the Free Software Foundation, either version 3 of the License, or # (at your option) any later version. # # wger Workout Manager is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the # GNU General Public License for more details. # # You should have received a copy of the GNU Affero General Public License # Standard Library import datetime import logging # Django from django.contrib.auth.models import User from django.urls import reverse # wger from wger.core.tests import api_base_test from wger.core.tests.base_testcase import ( STATUS_CODES_FAIL, WgerAddTestCase, WgerDeleteTestCase, WgerEditTestCase, WgerTestCase ) from wger.manager.models import ( Schedule, ScheduleStep, Workout ) from wger.utils.helpers import make_token logger = logging.getLogger(__name__) class ScheduleShareButtonTestCase(WgerTestCase): """ Test that the share button is correctly displayed and hidden """ def test_share_button(self): workout = Workout.objects.get(pk=2) response = self.client.get(workout.get_absolute_url()) self.assertFalse(response.context['show_shariff']) self.user_login('admin') response = self.client.get(workout.get_absolute_url()) self.assertTrue(response.context['show_shariff']) self.user_login('test') response = self.client.get(workout.get_absolute_url()) self.assertFalse(response.context['show_shariff']) class ScheduleAccessTestCase(WgerTestCase): """ Test accessing the workout page """ def test_access_shared(self): """ Test accessing the URL of a shared workout """ workout = Schedule.objects.get(pk=2) self.user_login('admin') response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 200) self.user_login('test') response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 200) self.user_logout() response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 200) def test_access_not_shared(self): """ Test accessing the URL of a private workout """ workout = Schedule.objects.get(pk=1) self.user_login('admin') response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 403) self.user_login('test') response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 200) self.user_logout() response = self.client.get(workout.get_absolute_url()) self.assertEqual(response.status_code, 403) class ScheduleRepresentationTestCase(WgerTestCase): """ Test the representation of a model """ def test_representation(self): """ Test that the representation of an object is correct """ self.assertEqual("{0}".format(Schedule.objects.get(pk=1)), 'my cool schedule that i found on the internet') class CreateScheduleTestCase(WgerAddTestCase): """ Tests adding a schedule """ object_class = Schedule url = 'manager:schedule:add' user_success = 'test' user_fail = False data = {'name': 'My cool schedule', 'start_date': datetime.date.today(), 'is_active': True, 'is_loop': True} class DeleteScheduleTestCase(WgerDeleteTestCase): """ Tests deleting a schedule """ object_class = Schedule url = 'manager:schedule:delete' pk = 1 user_success = 'test' user_fail = 'admin' class EditScheduleTestCase(WgerEditTestCase): """ Tests editing a schedule """ object_class = Schedule url = 'manager:schedule:edit' pk = 3 data = {'name': 'An updated name', 'start_date': datetime.date.today(), 'is_active': True, 'is_loop': True} class ScheduleTestCase(WgerTestCase): """ Other tests """ def schedule_detail_page(self): """ Helper function """ response = self.client.get(reverse('manager:schedule:view', kwargs={'pk': 2})) self.assertEqual(response.status_code, 200) self.assertContains(response, 'This schedule is a loop') schedule = Schedule.objects.get(pk=2) schedule.is_loop = False schedule.save() response = self.client.get(reverse('manager:schedule:view', kwargs={'pk': 2})) self.assertEqual(response.status_code, 200) self.assertNotContains(response, 'This schedule is a loop') def test_schedule_detail_page_owner(self): """ Tests the schedule detail page as the owning user """ self.user_login() self.schedule_detail_page() def test_schedule_overview(self): """ Tests the schedule overview """ self.user_login() response = self.client.get(reverse('manager:schedule:overview')) self.assertEqual(response.status_code, 200) self.assertEqual(len(response.context['schedules']), 3) self.assertTrue(response.context['schedules'][0].is_active) schedule = Schedule.objects.get(pk=4) schedule.is_active = False schedule.save() response = self.client.get(reverse('manager:schedule:overview')) self.assertEqual(response.status_code, 200) self.assertEqual(len(response.context['schedules']), 3) for i in range(0, 3): self.assertFalse(response.context['schedules'][i].is_active) def test_schedule_active(self): """ Tests that only one schedule can be active at a time (per user) """ def get_schedules(): schedule1 = Schedule.objects.get(pk=2) schedule2 = Schedule.objects.get(pk=3) schedule3 = Schedule.objects.get(pk=4) return (schedule1, schedule2, schedule3) self.user_login() (schedule1, schedule2, schedule3) = get_schedules() self.assertTrue(schedule3.is_active) schedule1.is_active = True schedule1.save() (schedule1, schedule2, schedule3) = get_schedules() self.assertTrue(schedule1.is_active) self.assertFalse(schedule2.is_active) self.assertFalse(schedule3.is_active) schedule2.is_active = True schedule2.save() (schedule1, schedule2, schedule3) = get_schedules() self.assertFalse(schedule1.is_active) self.assertTrue(schedule2.is_active) self.assertFalse(schedule3.is_active) def start_schedule(self, fail=False): """ Helper function """ schedule = Schedule.objects.get(pk=2) self.assertFalse(schedule.is_active) self.assertNotEqual(schedule.start_date, datetime.date.today()) response = self.client.get(reverse('manager:schedule:start', kwargs={'pk': 2})) schedule = Schedule.objects.get(pk=2) if fail: self.assertIn(response.status_code, STATUS_CODES_FAIL) self.assertFalse(schedule.is_active) self.assertNotEqual(schedule.start_date, datetime.date.today()) else: self.assertEqual(response.status_code, 302) self.assertTrue(schedule.is_active) self.assertEqual(schedule.start_date, datetime.date.today()) def test_start_schedule_owner(self): """ Tests starting a schedule as the owning user """ self.user_login() self.start_schedule() def test_start_schedule_other(self): """ Tests starting a schedule as a different user """ self.user_login('test') self.start_schedule(fail=True) def test_start_schedule_anonymous(self): """ Tests starting a schedule as a logged out user """ self.start_schedule(fail=True) class ScheduleEndDateTestCase(WgerTestCase): """ Test the schedule's get_end_date method """ def test_loop_schedule(self): """ Loop schedules have no end date """ schedule = Schedule.objects.get(pk=2) self.assertTrue(schedule.is_loop) self.assertFalse(schedule.get_end_date()) def test_calculate(self): """ Test the actual calculation Steps: 3, 5 and 2 weeks, starting on the 2013-04-21 """ schedule = Schedule.objects.get(pk=2) schedule.is_loop = False schedule.save() self.assertEqual(schedule.get_end_date(), datetime.date(2013, 6, 30)) def test_empty_schedule(self): """ Test the end date with an empty schedule """ schedule = Schedule.objects.get(pk=3) self.assertEqual(schedule.get_end_date(), schedule.start_date) class ScheduleModelTestCase(WgerTestCase): """ Tests the model methods """ def delete_objects(self, user): """ Helper function """ Workout.objects.filter(user=user).delete() Schedule.objects.filter(user=user).delete() def create_schedule(self, user, start_date=datetime.date.today(), is_loop=False): """ Helper function """ schedule = Schedule() schedule.user = user schedule.name = 'temp' schedule.is_active = True schedule.start_date = start_date schedule.is_loop = is_loop schedule.save() return schedule def create_workout(self, user): """ Helper function """ workout = Workout() workout.user = user workout.save() return workout def test_get_workout_steps_test_1(self): """ Test with no workouts and no schedule steps """ self.user_login('test') user = User.objects.get(pk=2) self.delete_objects(user) schedule = self.create_schedule(user) self.assertFalse(schedule.get_current_scheduled_workout()) def test_get_workout_steps_test_2(self): """ Test with one schedule step """ self.user_login('test') user = User.objects.get(pk=2) self.delete_objects(user) schedule = self.create_schedule(user) workout = self.create_workout(user) step = ScheduleStep() step.schedule = schedule step.workout = workout step.duration = 3 step.save() self.assertEqual(schedule.get_current_scheduled_workout().workout, workout) def test_get_workout_steps_test_3(self): """ Test with 3 steps """ self.user_login('test') user = User.objects.get(pk=2) self.delete_objects(user) <|fim▁hole|> start_date = datetime.date.today() - datetime.timedelta(weeks=4) schedule = self.create_schedule(user, start_date=start_date) workout = self.create_workout(user) step = ScheduleStep() step.schedule = schedule step.workout = workout step.duration = 3 step.order = 1 step.save() workout2 = self.create_workout(user) step2 = ScheduleStep() step2.schedule = schedule step2.workout = workout2 step2.duration = 1 step2.order = 2 step2.save() workout3 = self.create_workout(user) step3 = ScheduleStep() step3.schedule = schedule step3.workout = workout3 step3.duration = 2 step3.order = 3 step3.save() self.assertEqual(schedule.get_current_scheduled_workout().workout, workout2) def test_get_workout_steps_test_4(self): """ Test with 3 steps. Start is too far in the past, schedule ist not a loop """ self.user_login('test') user = User.objects.get(pk=2) self.delete_objects(user) start_date = datetime.date.today() - datetime.timedelta(weeks=7) schedule = self.create_schedule(user, start_date=start_date) workout = self.create_workout(user) step = ScheduleStep() step.schedule = schedule step.workout = workout step.duration = 3 step.order = 1 step.save() workout2 = self.create_workout(user) step2 = ScheduleStep() step2.schedule = schedule step2.workout = workout2 step2.duration = 1 step2.order = 2 step2.save() workout3 = self.create_workout(user) step3 = ScheduleStep() step3.schedule = schedule step3.workout = workout3 step3.duration = 2 step3.order = 3 step3.save() self.assertFalse(schedule.get_current_scheduled_workout()) def test_get_workout_steps_test_5(self): """ Test with 3 steps. Start is too far in the past but schedule is a loop """ self.user_login('test') user = User.objects.get(pk=2) self.delete_objects(user) start_date = datetime.date.today() - datetime.timedelta(weeks=7) schedule = self.create_schedule(user, start_date=start_date, is_loop=True) workout = self.create_workout(user) step = ScheduleStep() step.schedule = schedule step.workout = workout step.duration = 3 step.order = 1 step.save() workout2 = self.create_workout(user) step2 = ScheduleStep() step2.schedule = schedule step2.workout = workout2 step2.duration = 1 step2.order = 2 step2.save() workout3 = self.create_workout(user) step3 = ScheduleStep() step3.schedule = schedule step3.workout = workout3 step3.duration = 2 step3.order = 3 step3.save() self.assertTrue(schedule.get_current_scheduled_workout().workout, workout) class SchedulePdfExportTestCase(WgerTestCase): """ Test exporting a schedule as a pdf """ def export_pdf_token(self, pdf_type="log"): """ Helper function to test exporting a workout as a pdf using tokens """ user = User.objects.get(username='test') uid, token = make_token(user) response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 1, 'uidb64': uid, 'token': token})) self.assertEqual(response.status_code, 200) self.assertEqual(response['Content-Type'], 'application/pdf') self.assertEqual(response['Content-Disposition'], 'attachment; filename=Schedule-1-{0}.pdf'.format(pdf_type)) # Approximate size only self.assertGreater(int(response['Content-Length']), 29000) self.assertLess(int(response['Content-Length']), 35000) # Wrong or expired token uid = 'MQ' token = '3xv-57ef74923091fe7f186e' response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 1, 'uidb64': uid, 'token': token})) self.assertEqual(response.status_code, 403) def export_pdf(self, fail=False, pdf_type="log"): """ Helper function to test exporting a workout as a pdf """ response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 1})) if fail: self.assertIn(response.status_code, (403, 404, 302)) else: self.assertEqual(response.status_code, 200) self.assertEqual(response['Content-Type'], 'application/pdf') self.assertEqual(response['Content-Disposition'], 'attachment; filename=Schedule-1-{0}.pdf'.format(pdf_type)) # Approximate size only self.assertGreater(int(response['Content-Length']), 29000) self.assertLess(int(response['Content-Length']), 35000) def export_pdf_with_comments(self, fail=False, pdf_type="log"): """ Helper function to test exporting a workout as a pdf, with exercise coments """ user = User.objects.get(username='test') uid, token = make_token(user) response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 3, 'images': 0, 'comments': 1, 'uidb64': uid, 'token': token})) if fail: self.assertIn(response.status_code, (403, 404, 302)) else: self.assertEqual(response.status_code, 200) self.assertEqual(response['Content-Type'], 'application/pdf') self.assertEqual(response['Content-Disposition'], 'attachment; filename=Schedule-3-{0}.pdf'.format(pdf_type)) # Approximate size only self.assertGreater(int(response['Content-Length']), 29000) self.assertLess(int(response['Content-Length']), 35000) def export_pdf_with_images(self, fail=False, pdf_type="log"): """ Helper function to test exporting a workout as a pdf, with exercise images """ user = User.objects.get(username='test') uid, token = make_token(user) response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 3, 'images': 1, 'comments': 0, 'uidb64': uid, 'token': token})) if fail: self.assertIn(response.status_code, (403, 404, 302)) else: self.assertEqual(response.status_code, 200) self.assertEqual(response['Content-Type'], 'application/pdf') self.assertEqual(response['Content-Disposition'], 'attachment; filename=Schedule-3-{0}.pdf'.format(pdf_type)) # Approximate size only self.assertGreater(int(response['Content-Length']), 29000) self.assertLess(int(response['Content-Length']), 35000) def export_pdf_with_images_and_comments(self, fail=False, pdf_type="log"): """ Helper function to test exporting a workout as a pdf, with images and comments """ user = User.objects.get(username='test') uid, token = make_token(user) response = self.client.get(reverse('manager:schedule:pdf-{0}'.format(pdf_type), kwargs={'pk': 3, 'images': 1, 'comments': 1, 'uidb64': uid, 'token': token})) if fail: self.assertIn(response.status_code, (403, 404, 302)) else: self.assertEqual(response.status_code, 200) self.assertEqual(response['Content-Type'], 'application/pdf') self.assertEqual(response['Content-Disposition'], 'attachment; filename=Schedule-3-{0}.pdf'.format(pdf_type)) # Approximate size only self.assertGreater(int(response['Content-Length']), 29000) self.assertLess(int(response['Content-Length']), 35000) def test_export_pdf_log_anonymous(self): """ Tests exporting a workout as a pdf as an anonymous user """ self.export_pdf(fail=True) self.export_pdf_token() def test_export_pdf_log_owner(self): """ Tests exporting a workout as a pdf as the owner user """ self.user_login('test') self.export_pdf(fail=False) self.export_pdf_token() def test_export_pdf_log_other(self): """ Tests exporting a workout as a pdf as a logged user not owning the data """ self.user_login('admin') self.export_pdf(fail=True) self.export_pdf_token() def test_export_pdf_log_with_comments(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with comments """ self.user_login('test') self.export_pdf_with_comments(fail=False) self.export_pdf_token() def test_export_pdf_log_with_images(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with images """ self.user_login('test') self.export_pdf_with_images(fail=False) self.export_pdf_token() def test_export_pdf_log_with_images_and_comments(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with images andcomments """ self.user_login('test') self.export_pdf_with_images_and_comments(fail=False) self.export_pdf_token() # #####TABLE##### def test_export_pdf_table_anonymous(self): """ Tests exporting a workout as a pdf as an anonymous user """ self.export_pdf(fail=True, pdf_type="table") self.export_pdf_token(pdf_type="table") def test_export_pdf_table_owner(self): """ Tests exporting a workout as a pdf as the owner user """ self.user_login('test') self.export_pdf(fail=False, pdf_type="table") self.export_pdf_token(pdf_type="table") def test_export_pdf_table_other(self): """ Tests exporting a workout as a pdf as a logged user not owning the data """ self.user_login('admin') self.export_pdf(fail=True, pdf_type="table") self.export_pdf_token(pdf_type="table") def test_export_pdf_table_with_comments(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with comments """ self.user_login('test') self.export_pdf_with_comments(fail=False, pdf_type="table") self.export_pdf_token(pdf_type="table") def test_export_pdf_table_with_images(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with images """ self.user_login('test') self.export_pdf_with_images(fail=False, pdf_type="table") self.export_pdf_token(pdf_type="table") def test_export_pdf_table_with_images_and_comments(self, fail=False): """ Tests exporting a workout as a pdf as the owner user with images andcomments """ self.user_login('test') self.export_pdf_with_images_and_comments(fail=False, pdf_type="table") self.export_pdf_token(pdf_type="table") class ScheduleApiTestCase(api_base_test.ApiBaseResourceTestCase): """ Tests the schedule overview resource """ pk = 1 resource = Schedule private_resource = True data = {'name': 'An updated name', 'start_date': datetime.date.today(), 'is_active': True, 'is_loop': True}<|fim▁end|>
<|file_name|>KnightBlack.java<|end_file_name|><|fim▁begin|>package ru.job4j.chess.firuges.black; import ru.job4j.chess.ImpossibleMoveException; import ru.job4j.chess.firuges.Figure; import ru.job4j.chess.firuges.Cell; /** * Black Knight. * @author Natasha Panchina ([email protected]) * @version 1 * @since 18.08.2018 */ public class KnightBlack extends Figure { public KnightBlack(final Cell position) { super(position); } public Cell position() { return this.position; } @Override public Cell[] way(Cell source, Cell dest) throws ImpossibleMoveException { if (!this.isMove(source, dest)) { throw new ImpossibleMoveException(); } Cell[] steps = new Cell[]{dest}; return steps; } @Override public Figure copy(Cell dest) { return new KnightBlack(dest); } @Override public boolean isMove(Cell source, Cell dest) { boolean result = false; int deltax = Math.abs(source.getX() - dest.getX()); int deltay = Math.abs(source.getY() - dest.getY()); if (Math.abs(deltax - deltay) == 1 && deltax == 2<|fim▁hole|> } }<|fim▁end|>
|| Math.abs(deltax - deltay) == 1 && deltay == 2) { result = true; } return result;
<|file_name|>radix.go<|end_file_name|><|fim▁begin|>/* Copyright (c) 2020 Simon Schmidt Permission is hereby granted, free of charge, to any person obtaining a copy of this software and associated documentation files (the "Software"), to deal in the Software without restriction, including without limitation the rights to use, copy, modify, merge, publish, distribute, sublicense, and/or sell copies of the Software, and to permit persons to whom the Software is furnished to do so, subject to the following conditions: The above copyright notice and this permission notice shall be included in all copies or substantial portions of the Software. THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY, FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN THE SOFTWARE. */ package fasthttpradix import ( "github.com/valyala/fasthttp" rr "github.com/byte-mug/golibs/radixroute" "strings" ) func NormPath(str string) string { return "/"+strings.Trim(str,"/")+"/" } func InvalidPath(ctx *fasthttp.RequestCtx) { ctx.SetBody([]byte("404 Not Found\n")) ctx.SetStatusCode(fasthttp.StatusNotFound) } type handling struct{<|fim▁hole|> handle fasthttp.RequestHandler } type Router struct{ routes map[string]*rr.Tree } func (r *Router) getOrCreate(m string) *rr.Tree { t := r.routes[m] if t!=nil { return t } if r.routes==nil { r.routes = make(map[string]*rr.Tree) } r.routes[m] = rr.New() return r.routes[m] } func (r *Router) Handle(method string,path string,handler fasthttp.RequestHandler) { if handler==nil { panic("handler must not be nil") } h := &handling{handler} cpath := []byte(NormPath(path)) bpath := cpath[:len(cpath)-1] if method=="" { method = "DELETE,GET,HEAD,OPTIONS,PATCH,POST,PUT" } for _,m := range strings.Split(method,",") { rrt := r.getOrCreate(m) rrt.InsertRoute(bpath,h) rrt.InsertRoute(cpath,h) } } func (r *Router) RequestHandler(ctx *fasthttp.RequestCtx) { t := r.routes[string(ctx.Method())] if t==nil { InvalidPath(ctx) return } i,_ := t.Get(ctx.Path(),ctx.SetUserValue) h,ok := i.(*handling) if !ok { InvalidPath(ctx) return } h.handle(ctx) }<|fim▁end|>
<|file_name|>bitcoin_nb.ts<|end_file_name|><|fim▁begin|><?xml version="1.0" ?><!DOCTYPE TS><TS language="nb" version="2.0"> <defaultcodec>UTF-8</defaultcodec> <context> <name>AboutDialog</name> <message> <location filename="../forms/aboutdialog.ui" line="+14"/> <source>About cyphers</source> <translation>Om cyphers</translation> </message> <message> <location line="+39"/> <source>&lt;b&gt;cyphers&lt;/b&gt; version</source> <translation>&lt;b&gt;cyphers&lt;/b&gt; versjon</translation> </message> <message> <location line="+57"/> <source> This is experimental software. Distributed under the MIT/X11 software license, see the accompanying file COPYING or http://www.opensource.org/licenses/mit-license.php. This product includes software developed by the OpenSSL Project for use in the OpenSSL Toolkit (http://www.openssl.org/) and cryptographic software written by Eric Young ([email protected]) and UPnP software written by Thomas Bernard.</source> <translation> Dette er eksperimentell programvare. Distribuert under MIT/X11 programvarelisensen, se medfølgende fil COPYING eller http://www.opensource.org/licenses/mit-license.php. Dette produktet inneholder programvare utviklet av OpenSSL prosjektet for bruk i OpenSSL Toolkit (http://www.openssl.org/) og kryptografisk programvare skrevet av Eric Young ([email protected]) og UPnP programvare skrevet av Thomas Bernard.</translation> </message> <message> <location filename="../aboutdialog.cpp" line="+14"/> <source>Copyright</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>The cyphers developers</source> <translation type="unfinished"/> </message> </context> <context> <name>AddressBookPage</name> <message> <location filename="../forms/addressbookpage.ui" line="+14"/> <source>Address Book</source> <translation>Adressebok</translation> </message> <message> <location line="+19"/> <source>Double-click to edit address or label</source> <translation>Dobbeltklikk for å redigere adresse eller merkelapp</translation> </message> <message> <location line="+27"/> <source>Create a new address</source> <translation>Lag en ny adresse</translation> </message> <message> <location line="+14"/> <source>Copy the currently selected address to the system clipboard</source> <translation>Kopier den valgte adressen til systemets utklippstavle</translation> </message> <message> <location line="-11"/> <source>&amp;New Address</source> <translation>&amp;Ny Adresse</translation> </message> <message> <location filename="../addressbookpage.cpp" line="+63"/> <source>These are your cyphers addresses for receiving payments. You may want to give a different one to each sender so you can keep track of who is paying you.</source> <translation>Dette er dine cyphers-adresser for mottak av betalinger. Du kan gi forskjellige adresser til alle som skal betale deg for å holde bedre oversikt.</translation> </message> <message> <location filename="../forms/addressbookpage.ui" line="+14"/> <source>&amp;Copy Address</source> <translation>&amp;Kopier Adresse</translation> </message> <message> <location line="+11"/> <source>Show &amp;QR Code</source> <translation>Vis &amp;QR Kode</translation> </message> <message> <location line="+11"/> <source>Sign a message to prove you own a cyphers address</source> <translation>Signer en melding for å bevise at du eier en cyphers-adresse</translation> </message> <message> <location line="+3"/> <source>Sign &amp;Message</source> <translation>Signér &amp;Melding</translation> </message> <message> <location line="+25"/> <source>Delete the currently selected address from the list</source> <translation>Slett den valgte adressen fra listen.</translation> </message> <message> <location line="+27"/> <source>Export the data in the current tab to a file</source> <translation>Eksporter data fra nåværende fane til fil</translation> </message> <message> <location line="+3"/> <source>&amp;Export</source> <translation type="unfinished"/> </message> <message> <location line="-44"/> <source>Verify a message to ensure it was signed with a specified cyphers address</source> <translation>Verifiser en melding for å være sikker på at den ble signert av en angitt cyphers-adresse</translation> </message> <message> <location line="+3"/> <source>&amp;Verify Message</source> <translation>&amp;Verifiser Melding</translation> </message> <message> <location line="+14"/> <source>&amp;Delete</source> <translation>&amp;Slett</translation> </message> <message> <location filename="../addressbookpage.cpp" line="-5"/> <source>These are your cyphers addresses for sending payments. Always check the amount and the receiving address before sending coins.</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>Copy &amp;Label</source> <translation>Kopier &amp;Merkelapp</translation> </message> <message> <location line="+1"/> <source>&amp;Edit</source> <translation>&amp;Rediger</translation> </message> <message> <location line="+1"/> <source>Send &amp;Coins</source> <translation>Send &amp;Coins</translation> </message> <message> <location line="+260"/> <source>Export Address Book Data</source> <translation>Eksporter adressebok</translation> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Kommaseparert fil (*.csv)</translation> </message> <message> <location line="+13"/> <source>Error exporting</source> <translation>Feil ved eksportering</translation> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation>Kunne ikke skrive til filen %1.</translation> </message> </context> <context> <name>AddressTableModel</name> <message> <location filename="../addresstablemodel.cpp" line="+144"/> <source>Label</source> <translation>Merkelapp</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Adresse</translation> </message> <message> <location line="+36"/> <source>(no label)</source> <translation>(ingen merkelapp)</translation> </message> </context> <context> <name>AskPassphraseDialog</name> <message> <location filename="../forms/askpassphrasedialog.ui" line="+26"/> <source>Passphrase Dialog</source> <translation>Dialog for Adgangsfrase</translation> </message> <message> <location line="+21"/> <source>Enter passphrase</source> <translation>Angi adgangsfrase</translation> </message> <message> <location line="+14"/> <source>New passphrase</source> <translation>Ny adgangsfrase</translation> </message> <message> <location line="+14"/> <source>Repeat new passphrase</source> <translation>Gjenta ny adgangsfrase</translation> </message> <message> <location filename="../askpassphrasedialog.cpp" line="+33"/> <source>Enter the new passphrase to the wallet.&lt;br/&gt;Please use a passphrase of &lt;b&gt;10 or more random characters&lt;/b&gt;, or &lt;b&gt;eight or more words&lt;/b&gt;.</source> <translation>Skriv inn den nye adgangsfrasen for lommeboken.&lt;br/&gt;Vennligst bruk en adgangsfrase med &lt;b&gt;10 eller flere tilfeldige tegn&lt;/b&gt;, eller &lt;b&gt;åtte eller flere ord&lt;/b&gt;.</translation> </message> <message> <location line="+1"/> <source>Encrypt wallet</source> <translation>Krypter lommebok</translation> </message> <message> <location line="+3"/> <source>This operation needs your wallet passphrase to unlock the wallet.</source> <translation>Denne operasjonen krever adgangsfrasen til lommeboken for å låse den opp.</translation> </message> <message> <location line="+5"/> <source>Unlock wallet</source> <translation>Lås opp lommebok</translation> </message> <message> <location line="+3"/> <source>This operation needs your wallet passphrase to decrypt the wallet.</source> <translation>Denne operasjonen krever adgangsfrasen til lommeboken for å dekryptere den.</translation> </message> <message> <location line="+5"/> <source>Decrypt wallet</source> <translation>Dekrypter lommebok</translation> </message> <message> <location line="+3"/> <source>Change passphrase</source> <translation>Endre adgangsfrase</translation> </message> <message> <location line="+1"/> <source>Enter the old and new passphrase to the wallet.</source> <translation>Skriv inn gammel og ny adgangsfrase for lommeboken.</translation> </message> <message> <location line="+46"/> <source>Confirm wallet encryption</source> <translation>Bekreft kryptering av lommebok</translation> </message> <message> <location line="+1"/> <source>Warning: If you encrypt your wallet and lose your passphrase, you will &lt;b&gt;LOSE ALL OF YOUR cyphersS&lt;/b&gt;!</source> <translation>Advarsel: Hvis du krypterer lommeboken og mister adgangsfrasen, så vil du &lt;b&gt;MISTE ALLE DINE cyphersS&lt;/b&gt;!</translation> </message> <message> <location line="+0"/> <source>Are you sure you wish to encrypt your wallet?</source> <translation>Er du sikker på at du vil kryptere lommeboken?</translation> </message> <message> <location line="+15"/> <source>IMPORTANT: Any previous backups you have made of your wallet file should be replaced with the newly generated, encrypted wallet file. For security reasons, previous backups of the unencrypted wallet file will become useless as soon as you start using the new, encrypted wallet.</source> <translation>VIKTIG: Tidligere sikkerhetskopier av din lommebok-fil, bør erstattes med den nylig genererte, krypterte filen, da de blir ugyldiggjort av sikkerhetshensyn så snart du begynner å bruke den nye krypterte lommeboken.</translation> </message> <message> <location line="+100"/> <location line="+24"/> <source>Warning: The Caps Lock key is on!</source> <translation>Advarsel: Caps Lock er på !</translation> </message> <message> <location line="-130"/> <location line="+58"/> <source>Wallet encrypted</source> <translation>Lommebok kryptert</translation> </message> <message> <location line="-56"/> <source>cyphers will close now to finish the encryption process. Remember that encrypting your wallet cannot fully protect your cypherss from being stolen by malware infecting your computer.</source> <translation>cyphers vil nå lukkes for å fullføre krypteringsprosessen. Husk at kryptering av lommeboken ikke fullt ut kan beskytte dine cypherss fra å bli stjålet om skadevare infiserer datamaskinen.</translation> </message> <message> <location line="+13"/> <location line="+7"/> <location line="+42"/> <location line="+6"/> <source>Wallet encryption failed</source> <translation>Kryptering av lommebok feilet</translation> </message> <message> <location line="-54"/> <source>Wallet encryption failed due to an internal error. Your wallet was not encrypted.</source> <translation>Kryptering av lommebok feilet på grunn av en intern feil. Din lommebok ble ikke kryptert.</translation> </message> <message> <location line="+7"/> <location line="+48"/> <source>The supplied passphrases do not match.</source> <translation>De angitte adgangsfrasene er ulike.</translation> </message> <message> <location line="-37"/> <source>Wallet unlock failed</source> <translation>Opplåsing av lommebok feilet</translation> </message> <message> <location line="+1"/> <location line="+11"/> <location line="+19"/> <source>The passphrase entered for the wallet decryption was incorrect.</source> <translation>Adgangsfrasen angitt for dekryptering av lommeboken var feil.</translation> </message> <message> <location line="-20"/> <source>Wallet decryption failed</source> <translation>Dekryptering av lommebok feilet</translation> </message> <message> <location line="+14"/> <source>Wallet passphrase was successfully changed.</source> <translation>Adgangsfrase for lommebok endret.</translation> </message> </context> <context> <name>BitcoinGUI</name> <message> <location filename="../bitcoingui.cpp" line="+233"/> <source>Sign &amp;message...</source> <translation>Signer &amp;melding...</translation> </message> <message> <location line="+280"/> <source>Synchronizing with network...</source> <translation>Synkroniserer med nettverk...</translation> </message> <message> <location line="-349"/> <source>&amp;Overview</source> <translation>&amp;Oversikt</translation> </message> <message> <location line="+1"/> <source>Show general overview of wallet</source> <translation>Vis generell oversikt over lommeboken</translation> </message> <message> <location line="+20"/> <source>&amp;Transactions</source> <translation>&amp;Transaksjoner</translation> </message> <message> <location line="+1"/> <source>Browse transaction history</source> <translation>Vis transaksjonshistorikk</translation> </message> <message> <location line="+7"/> <source>Edit the list of stored addresses and labels</source> <translation>Rediger listen over adresser og deres merkelapper</translation> </message> <message> <location line="-14"/> <source>Show the list of addresses for receiving payments</source> <translation>Vis listen over adresser for mottak av betalinger</translation> </message> <message> <location line="+31"/> <source>E&amp;xit</source> <translation>&amp;Avslutt</translation> </message> <message> <location line="+1"/> <source>Quit application</source> <translation>Avslutt applikasjonen</translation> </message> <message> <location line="+4"/> <source>Show information about cyphers</source> <translation>Vis informasjon om cyphers</translation> </message> <message> <location line="+2"/> <source>About &amp;Qt</source> <translation>Om &amp;Qt</translation> </message> <message> <location line="+1"/> <source>Show information about Qt</source> <translation>Vis informasjon om Qt</translation> </message> <message> <location line="+2"/> <source>&amp;Options...</source> <translation>&amp;Innstillinger...</translation> </message> <message> <location line="+6"/> <source>&amp;Encrypt Wallet...</source> <translation>&amp;Krypter Lommebok...</translation> </message> <message> <location line="+3"/> <source>&amp;Backup Wallet...</source> <translation>Lag &amp;Sikkerhetskopi av Lommebok...</translation> </message> <message> <location line="+2"/> <source>&amp;Change Passphrase...</source> <translation>&amp;Endre Adgangsfrase...</translation> </message> <message> <location line="+285"/> <source>Importing blocks from disk...</source> <translation>Importere blokker...</translation> </message> <message> <location line="+3"/> <source>Reindexing blocks on disk...</source> <translation>Re-indekserer blokker på disk...</translation> </message> <message> <location line="-347"/> <source>Send coins to a cyphers address</source> <translation>Send til en cyphers-adresse</translation> </message> <message> <location line="+49"/> <source>Modify configuration options for cyphers</source> <translation>Endre oppsett for cyphers</translation> </message> <message> <location line="+9"/> <source>Backup wallet to another location</source> <translation>Sikkerhetskopiér lommebok til annet sted</translation> </message> <message> <location line="+2"/> <source>Change the passphrase used for wallet encryption</source> <translation>Endre adgangsfrasen brukt for kryptering av lommebok</translation> </message> <message> <location line="+6"/> <source>&amp;Debug window</source> <translation>&amp;Feilsøkingsvindu</translation> </message> <message> <location line="+1"/> <source>Open debugging and diagnostic console</source> <translation>Åpne konsoll for feilsøk og diagnostikk</translation> </message> <message> <location line="-4"/> <source>&amp;Verify message...</source> <translation>&amp;Verifiser melding...</translation> </message> <message> <location line="-165"/> <location line="+530"/> <source>cyphers</source> <translation>cyphers</translation> </message> <message> <location line="-530"/> <source>Wallet</source> <translation>Lommebok</translation> </message> <message> <location line="+101"/> <source>&amp;Send</source> <translation>&amp;Send</translation> </message> <message> <location line="+7"/> <source>&amp;Receive</source> <translation>&amp;Motta</translation> </message> <message> <location line="+14"/> <source>&amp;Addresses</source> <translation>&amp;Adressebok</translation> </message> <message> <location line="+22"/> <source>&amp;About cyphers</source> <translation>&amp;Om cyphers</translation> </message> <message> <location line="+9"/> <source>&amp;Show / Hide</source> <translation>&amp;Gjem / vis</translation> </message> <message> <location line="+1"/> <source>Show or hide the main Window</source> <translation>Vis eller skjul hovedvinduet</translation> </message> <message> <location line="+3"/> <source>Encrypt the private keys that belong to your wallet</source> <translation>Krypter de private nøklene som tilhører lommeboken din</translation> </message> <message> <location line="+7"/> <source>Sign messages with your cyphers addresses to prove you own them</source> <translation>Signér en melding for å bevise at du eier denne adressen</translation> </message> <message> <location line="+2"/> <source>Verify messages to ensure they were signed with specified cyphers addresses</source> <translation>Bekreft meldinger for å være sikker på at de ble signert av en angitt cyphers-adresse</translation> </message> <message> <location line="+28"/> <source>&amp;File</source> <translation>&amp;Fil</translation> </message> <message> <location line="+7"/> <source>&amp;Settings</source> <translation>&amp;Innstillinger</translation> </message> <message> <location line="+6"/> <source>&amp;Help</source> <translation>&amp;Hjelp</translation> </message> <message> <location line="+9"/> <source>Tabs toolbar</source> <translation>Verktøylinje for faner</translation> </message> <message> <location line="+17"/> <location line="+10"/> <source>[testnet]</source> <translation>[testnett]</translation> </message> <message> <location line="+47"/> <source>cyphers client</source> <translation>cyphersklient</translation> </message> <message numerus="yes"> <location line="+141"/> <source>%n active connection(s) to cyphers network</source> <translation><numerusform>%n aktiv forbindelse til cyphers-nettverket</numerusform><numerusform>%n aktive forbindelser til cyphers-nettverket</numerusform></translation> </message> <message> <location line="+22"/> <source>No block source available...</source> <translation type="unfinished"/> </message> <message> <location line="+12"/> <source>Processed %1 of %2 (estimated) blocks of transaction history.</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Processed %1 blocks of transaction history.</source> <translation>Lastet %1 blokker med transaksjonshistorikk.</translation> </message> <message numerus="yes"> <location line="+20"/> <source>%n hour(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n day(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n week(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+4"/> <source>%1 behind</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>Last received block was generated %1 ago.</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Transactions after this will not yet be visible.</source> <translation>Transaksjoner etter dette vil ikke være synlige enda.</translation> </message> <message> <location line="+22"/> <source>Error</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Warning</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Information</source> <translation type="unfinished"/> </message> <message> <location line="+70"/> <source>This transaction is over the size limit. You can still send it for a fee of %1, which goes to the nodes that process your transaction and helps to support the network. Do you want to pay the fee?</source> <translation>Denne transaksjonen overstiger størrelsesbegrensningen. Du kan likevel sende den med et gebyr på %1, som går til nodene som prosesserer transaksjonen din og støtter nettverket. Vil du betale gebyret?</translation> </message> <message> <location line="-140"/> <source>Up to date</source> <translation>Ajour</translation> </message> <message> <location line="+31"/> <source>Catching up...</source> <translation>Kommer ajour...</translation> </message> <message> <location line="+113"/> <source>Confirm transaction fee</source> <translation>Bekreft transaksjonsgebyr</translation> </message> <message> <location line="+8"/> <source>Sent transaction</source> <translation>Sendt transaksjon</translation> </message> <message> <location line="+0"/> <source>Incoming transaction</source> <translation>Innkommende transaksjon</translation> </message> <message> <location line="+1"/> <source>Date: %1 Amount: %2 Type: %3 Address: %4 </source> <translation>Dato: %1 Beløp: %2 Type: %3 Adresse: %4 </translation> </message> <message> <location line="+33"/> <location line="+23"/> <source>URI handling</source> <translation>URI håndtering</translation> </message> <message> <location line="-23"/> <location line="+23"/> <source>URI can not be parsed! This can be caused by an invalid cyphers address or malformed URI parameters.</source> <translation>URI kunne ikke tolkes! Dette kan forårsakes av en ugyldig cyphers-adresse eller feil i URI-parametere.</translation> </message> <message> <location line="+17"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;unlocked&lt;/b&gt;</source> <translation>Lommeboken er &lt;b&gt;kryptert&lt;/b&gt; og for tiden &lt;b&gt;ulåst&lt;/b&gt;</translation> </message> <message> <location line="+8"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;locked&lt;/b&gt;</source> <translation>Lommeboken er &lt;b&gt;kryptert&lt;/b&gt; og for tiden &lt;b&gt;låst&lt;/b&gt;</translation> </message> <message> <location filename="../bitcoin.cpp" line="+111"/> <source>A fatal error occurred. cyphers can no longer continue safely and will quit.</source> <translation>En fatal feil har inntruffet. Det er ikke trygt å fortsette og cyphers må derfor avslutte.</translation> </message> </context> <context> <name>ClientModel</name> <message> <location filename="../clientmodel.cpp" line="+104"/> <source>Network Alert</source> <translation>Nettverksvarsel</translation> </message> </context> <context> <name>EditAddressDialog</name> <message> <location filename="../forms/editaddressdialog.ui" line="+14"/> <source>Edit Address</source> <translation>Rediger adresse</translation> </message> <message> <location line="+11"/> <source>&amp;Label</source> <translation>&amp;Merkelapp</translation> </message> <message> <location line="+10"/> <source>The label associated with this address book entry</source> <translation>Merkelappen koblet til denne adressen i adresseboken</translation> </message> <message> <location line="+7"/> <source>&amp;Address</source> <translation>&amp;Adresse</translation> </message> <message> <location line="+10"/> <source>The address associated with this address book entry. This can only be modified for sending addresses.</source> <translation>Adressen til denne oppføringen i adresseboken. Denne kan kun endres for utsendingsadresser.</translation> </message> <message> <location filename="../editaddressdialog.cpp" line="+21"/> <source>New receiving address</source> <translation>Ny mottaksadresse</translation> </message> <message> <location line="+4"/> <source>New sending address</source> <translation>Ny utsendingsadresse</translation> </message> <message> <location line="+3"/> <source>Edit receiving address</source> <translation>Rediger mottaksadresse</translation> </message> <message> <location line="+4"/> <source>Edit sending address</source> <translation>Rediger utsendingsadresse</translation> </message> <message> <location line="+76"/> <source>The entered address &quot;%1&quot; is already in the address book.</source> <translation>Den oppgitte adressen &quot;%1&quot; er allerede i adresseboken.</translation> </message> <message> <location line="-5"/> <source>The entered address &quot;%1&quot; is not a valid cyphers address.</source> <translation>Den angitte adressed &quot;%1&quot; er ikke en gyldig cyphers-adresse.</translation> </message> <message> <location line="+10"/> <source>Could not unlock wallet.</source> <translation>Kunne ikke låse opp lommeboken.</translation> </message> <message> <location line="+5"/> <source>New key generation failed.</source> <translation>Generering av ny nøkkel feilet.</translation> </message> </context> <context> <name>GUIUtil::HelpMessageBox</name> <message> <location filename="../guiutil.cpp" line="+424"/> <location line="+12"/> <source>cyphers-Qt</source> <translation>cyphers-Qt</translation> </message> <message> <location line="-12"/> <source>version</source> <translation>versjon</translation> </message> <message> <location line="+2"/> <source>Usage:</source> <translation>Bruk:</translation> </message> <message> <location line="+1"/> <source>command-line options</source> <translation>kommandolinjevalg</translation> </message> <message> <location line="+4"/> <source>UI options</source> <translation>valg i brukergrensesnitt</translation> </message> <message> <location line="+1"/> <source>Set language, for example &quot;de_DE&quot; (default: system locale)</source> <translation>Sett språk, for eksempel &quot;nb_NO&quot; (standardverdi: fra operativsystem)</translation> </message> <message> <location line="+1"/> <source>Start minimized</source> <translation>Start minimert </translation> </message> <message> <location line="+1"/> <source>Show splash screen on startup (default: 1)</source> <translation>Vis splashskjerm ved oppstart (standardverdi: 1)</translation> </message> </context> <context> <name>OptionsDialog</name> <message> <location filename="../forms/optionsdialog.ui" line="+14"/> <source>Options</source> <translation>Innstillinger</translation> </message> <message> <location line="+16"/> <source>&amp;Main</source> <translation>&amp;Hoved</translation> </message> <message> <location line="+6"/> <source>Optional transaction fee per kB that helps make sure your transactions are processed quickly. Most transactions are 1 kB.</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Pay transaction &amp;fee</source> <translation>Betal transaksjons&amp;gebyr</translation> </message> <message> <location line="+31"/> <source>Automatically start cyphers after logging in to the system.</source> <translation>Start cyphers automatisk etter innlogging.</translation> </message> <message> <location line="+3"/> <source>&amp;Start cyphers on system login</source> <translation>&amp;Start cyphers ved systeminnlogging</translation> </message> <message> <location line="+35"/> <source>Reset all client options to default.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Reset Options</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>&amp;Network</source> <translation>&amp;Nettverk</translation> </message> <message> <location line="+6"/> <source>Automatically open the cyphers client port on the router. This only works when your router supports UPnP and it is enabled.</source> <translation>Åpne automatisk cyphers klientporten på ruteren. Dette virker kun om din ruter støtter UPnP og dette er påslått.</translation> </message> <message> <location line="+3"/> <source>Map port using &amp;UPnP</source> <translation>Sett opp port vha. &amp;UPnP</translation> </message> <message> <location line="+7"/> <source>Connect to the cyphers network through a SOCKS proxy (e.g. when connecting through Tor).</source> <translation>Koble til cyphers-nettverket gjennom en SOCKS proxy (f.eks. ved tilkobling gjennom Tor).</translation> </message> <message> <location line="+3"/> <source>&amp;Connect through SOCKS proxy:</source> <translation>&amp;Koble til gjenom SOCKS proxy:</translation> </message> <message> <location line="+9"/> <source>Proxy &amp;IP:</source> <translation>Proxy &amp;IP:</translation> </message> <message> <location line="+19"/> <source>IP address of the proxy (e.g. 127.0.0.1)</source> <translation>IP-adresse for mellomtjener (f.eks. 127.0.0.1)</translation> </message> <message> <location line="+7"/> <source>&amp;Port:</source> <translation>&amp;Port:</translation> </message> <message> <location line="+19"/> <source>Port of the proxy (e.g. 9050)</source> <translation>Proxyens port (f.eks. 9050)</translation> </message> <message> <location line="+7"/> <source>SOCKS &amp;Version:</source> <translation>SOCKS &amp;Versjon:</translation> </message> <message> <location line="+13"/> <source>SOCKS version of the proxy (e.g. 5)</source> <translation>Proxyens SOCKS versjon (f.eks. 5)</translation> </message> <message> <location line="+36"/> <source>&amp;Window</source> <translation>&amp;Vindu</translation> </message> <message> <location line="+6"/> <source>Show only a tray icon after minimizing the window.</source> <translation>Vis kun ikon i systemkurv etter minimering av vinduet.</translation> </message> <message> <location line="+3"/> <source>&amp;Minimize to the tray instead of the taskbar</source> <translation>&amp;Minimer til systemkurv istedenfor oppgavelinjen</translation> </message> <message> <location line="+7"/> <source>Minimize instead of exit the application when the window is closed. When this option is enabled, the application will be closed only after selecting Quit in the menu.</source> <translation>Minimerer vinduet istedenfor å avslutte applikasjonen når vinduet lukkes. Når dette er slått på avsluttes applikasjonen kun ved å velge avslutt i menyen.</translation> </message> <message> <location line="+3"/> <source>M&amp;inimize on close</source> <translation>M&amp;inimer ved lukking</translation> </message> <message> <location line="+21"/> <source>&amp;Display</source> <translation>&amp;Visning</translation> </message> <message> <location line="+8"/> <source>User Interface &amp;language:</source> <translation>&amp;Språk for brukergrensesnitt</translation> </message> <message> <location line="+13"/> <source>The user interface language can be set here. This setting will take effect after restarting cyphers.</source> <translation>Språket for brukergrensesnittet kan settes her. Innstillingen trer i kraft ved omstart av cyphers.</translation> </message> <message> <location line="+11"/> <source>&amp;Unit to show amounts in:</source> <translation>&amp;Enhet for visning av beløper:</translation> </message> <message> <location line="+13"/> <source>Choose the default subdivision unit to show in the interface and when sending coins.</source> <translation>Velg standard delt enhet for visning i grensesnittet og for sending av cypherss.</translation> </message> <message> <location line="+9"/> <source>Whether to show cyphers addresses in the transaction list or not.</source> <translation>Om cyphers-adresser skal vises i transaksjonslisten eller ikke.</translation> </message> <message> <location line="+3"/> <source>&amp;Display addresses in transaction list</source> <translation>&amp;Vis adresser i transaksjonslisten</translation> </message> <message> <location line="+71"/> <source>&amp;OK</source> <translation>&amp;OK</translation> </message> <message> <location line="+7"/> <source>&amp;Cancel</source> <translation>&amp;Avbryt</translation> </message> <message> <location line="+10"/> <source>&amp;Apply</source> <translation>&amp;Bruk</translation> </message> <message> <location filename="../optionsdialog.cpp" line="+53"/> <source>default</source> <translation>standardverdi</translation> </message> <message> <location line="+130"/> <source>Confirm options reset</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Some settings may require a client restart to take effect.</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Do you want to proceed?</source> <translation type="unfinished"/> </message> <message> <location line="+42"/> <location line="+9"/> <source>Warning</source> <translation>Advarsel</translation> </message> <message> <location line="-9"/> <location line="+9"/> <source>This setting will take effect after restarting cyphers.</source> <translation>Denne innstillingen trer i kraft etter omstart av cyphers.</translation> </message> <message> <location line="+29"/> <source>The supplied proxy address is invalid.</source> <translation>Angitt proxyadresse er ugyldig.</translation> </message> </context> <context> <name>OverviewPage</name> <message> <location filename="../forms/overviewpage.ui" line="+14"/> <source>Form</source> <translation>Skjema</translation> </message> <message> <location line="+50"/> <location line="+166"/> <source>The displayed information may be out of date. Your wallet automatically synchronizes with the cyphers network after a connection is established, but this process has not completed yet.</source> <translation>Informasjonen som vises kan være foreldet. Din lommebok synkroniseres automatisk med cyphers-nettverket etter at tilkobling er opprettet, men denne prosessen er ikke ferdig enda.</translation> </message> <message> <location line="-124"/> <source>Balance:</source> <translation>Saldo:</translation> </message> <message> <location line="+29"/> <source>Unconfirmed:</source> <translation>Ubekreftet</translation> </message> <message> <location line="-78"/> <source>Wallet</source> <translation>Lommebok</translation> </message> <message> <location line="+107"/> <source>Immature:</source> <translation>Umoden:</translation> </message> <message> <location line="+13"/> <source>Mined balance that has not yet matured</source> <translation>Minet saldo har ikke modnet enda</translation> </message> <message> <location line="+46"/> <source>&lt;b&gt;Recent transactions&lt;/b&gt;</source> <translation>&lt;b&gt;Siste transaksjoner&lt;/b&gt;</translation> </message> <message> <location line="-101"/> <source>Your current balance</source> <translation>Din nåværende saldo</translation> </message> <message> <location line="+29"/> <source>Total of transactions that have yet to be confirmed, and do not yet count toward the current balance</source> <translation>Totalt antall ubekreftede transaksjoner som ikke telles med i saldo enda</translation> </message> <message> <location filename="../overviewpage.cpp" line="+116"/> <location line="+1"/> <source>out of sync</source> <translation>ute av synk</translation> </message> </context> <context> <name>PaymentServer</name> <message> <location filename="../paymentserver.cpp" line="+107"/> <source>Cannot start cyphers: click-to-pay handler</source> <translation>Kan ikke starte cyphers: klikk-og-betal håndterer</translation> </message> </context> <context> <name>QRCodeDialog</name> <message> <location filename="../forms/qrcodedialog.ui" line="+14"/> <source>QR Code Dialog</source> <translation>Dialog for QR Kode</translation> </message> <message> <location line="+59"/> <source>Request Payment</source> <translation>Etterspør Betaling</translation> </message> <message> <location line="+56"/> <source>Amount:</source> <translation>Beløp:</translation> </message> <message> <location line="-44"/> <source>Label:</source> <translation>Merkelapp:</translation> </message> <message> <location line="+19"/> <source>Message:</source> <translation>Melding:</translation> </message> <message> <location line="+71"/> <source>&amp;Save As...</source> <translation>&amp;Lagre Som...</translation> </message> <message> <location filename="../qrcodedialog.cpp" line="+62"/> <source>Error encoding URI into QR Code.</source> <translation>Feil ved koding av URI i QR kode.</translation> </message> <message> <location line="+40"/> <source>The entered amount is invalid, please check.</source> <translation>Angitt beløp er ugyldig.</translation> </message> <message> <location line="+23"/> <source>Resulting URI too long, try to reduce the text for label / message.</source> <translation>Resulterende URI for lang, prøv å redusere teksten for merkelapp / melding.</translation> </message> <message> <location line="+25"/> <source>Save QR Code</source> <translation>Lagre QR Kode</translation> </message> <message> <location line="+0"/> <source>PNG Images (*.png)</source> <translation>PNG bilder (*.png)</translation> </message> </context> <context> <name>RPCConsole</name> <message> <location filename="../forms/rpcconsole.ui" line="+46"/> <source>Client name</source> <translation>Klientnavn</translation> </message> <message> <location line="+10"/> <location line="+23"/> <location line="+26"/> <location line="+23"/> <location line="+23"/> <location line="+36"/> <location line="+53"/> <location line="+23"/> <location line="+23"/> <location filename="../rpcconsole.cpp" line="+339"/> <source>N/A</source> <translation>-</translation> </message> <message> <location line="-217"/> <source>Client version</source> <translation>Klientversjon</translation> </message> <message> <location line="-45"/> <source>&amp;Information</source> <translation>&amp;Informasjon</translation> </message> <message> <location line="+68"/> <source>Using OpenSSL version</source> <translation>Bruker OpenSSL versjon</translation> </message> <message> <location line="+49"/> <source>Startup time</source> <translation>Oppstartstidspunkt</translation> </message> <message> <location line="+29"/> <source>Network</source> <translation>Nettverk</translation> </message> <message> <location line="+7"/> <source>Number of connections</source> <translation>Antall tilkoblinger</translation> </message> <message> <location line="+23"/> <source>On testnet</source> <translation>På testnett</translation> </message> <message> <location line="+23"/> <source>Block chain</source> <translation>Blokkjeden</translation> </message> <message> <location line="+7"/> <source>Current number of blocks</source> <translation>Nåværende antall blokker</translation> </message> <message> <location line="+23"/> <source>Estimated total blocks</source> <translation>Estimert totalt antall blokker</translation> </message> <message> <location line="+23"/> <source>Last block time</source> <translation>Tidspunkt for siste blokk</translation> </message> <message> <location line="+52"/> <source>&amp;Open</source> <translation>&amp;Åpne</translation> </message> <message> <location line="+16"/> <source>Command-line options</source> <translation>Kommandolinjevalg</translation> </message> <message> <location line="+7"/> <source>Show the cyphers-Qt help message to get a list with possible cyphers command-line options.</source> <translation>Vis cyphers-Qt hjelpemelding for å få en liste med mulige kommandolinjevalg.</translation> </message> <message> <location line="+3"/> <source>&amp;Show</source> <translation>&amp;Vis</translation> </message> <message> <location line="+24"/> <source>&amp;Console</source> <translation>&amp;Konsoll</translation> </message> <message> <location line="-260"/> <source>Build date</source> <translation>Byggedato</translation> </message> <message> <location line="-104"/> <source>cyphers - Debug window</source> <translation>cyphers - vindu for feilsøk</translation> </message> <message> <location line="+25"/> <source>cyphers Core</source> <translation>cyphers Kjerne</translation> </message> <message> <location line="+279"/> <source>Debug log file</source> <translation>Loggfil for feilsøk</translation> </message> <message> <location line="+7"/> <source>Open the cyphers debug log file from the current data directory. This can take a few seconds for large log files.</source> <translation>Åpne cyphers loggfil for feilsøk fra datamappen. Dette kan ta noen sekunder for store loggfiler.</translation> </message> <message> <location line="+102"/> <source>Clear console</source> <translation>Tøm konsoll</translation> </message> <message> <location filename="../rpcconsole.cpp" line="-30"/> <source>Welcome to the cyphers RPC console.</source> <translation>Velkommen til cyphers RPC konsoll.</translation> </message> <message> <location line="+1"/> <source>Use up and down arrows to navigate history, and &lt;b&gt;Ctrl-L&lt;/b&gt; to clear screen.</source> <translation>Bruk opp og ned pil for å navigere historikken, og &lt;b&gt;Ctrl-L&lt;/b&gt; for å tømme skjermen.</translation> </message> <message> <location line="+1"/> <source>Type &lt;b&gt;help&lt;/b&gt; for an overview of available commands.</source> <translation>Skriv &lt;b&gt;help&lt;/b&gt; for en oversikt over kommandoer.</translation> </message> </context> <context> <name>SendCoinsDialog</name> <message> <location filename="../forms/sendcoinsdialog.ui" line="+14"/> <location filename="../sendcoinsdialog.cpp" line="+124"/> <location line="+5"/> <location line="+5"/> <location line="+5"/> <location line="+6"/> <location line="+5"/> <location line="+5"/> <source>Send Coins</source> <translation>Send cypherss</translation> </message> <message> <location line="+50"/> <source>Send to multiple recipients at once</source> <translation>Send til flere enn én mottaker</translation> </message> <message> <location line="+3"/> <source>Add &amp;Recipient</source> <translation>&amp;Legg til Mottaker</translation> </message> <message> <location line="+20"/> <source>Remove all transaction fields</source> <translation>Fjern alle transaksjonsfelter</translation> </message> <message> <location line="+3"/> <source>Clear &amp;All</source> <translation>Fjern &amp;Alt</translation> </message> <message> <location line="+22"/> <source>Balance:</source> <translation>Saldo:</translation> </message> <message> <location line="+10"/> <source>123.456 BTC</source> <translation>123.456 BTC</translation> </message> <message> <location line="+31"/> <source>Confirm the send action</source> <translation>Bekreft sending</translation> </message> <message> <location line="+3"/> <source>S&amp;end</source> <translation>S&amp;end</translation> </message> <message> <location filename="../sendcoinsdialog.cpp" line="-59"/> <source>&lt;b&gt;%1&lt;/b&gt; to %2 (%3)</source> <translation>&lt;b&gt;%1&lt;/b&gt; til %2 (%3)</translation> </message> <message> <location line="+5"/> <source>Confirm send coins</source> <translation>Bekreft sending av cypherss</translation> </message> <message> <location line="+1"/> <source>Are you sure you want to send %1?</source> <translation>Er du sikker på at du vil sende %1?</translation> </message> <message> <location line="+0"/> <source> and </source> <translation> og </translation> </message> <message> <location line="+23"/> <source>The recipient address is not valid, please recheck.</source> <translation>Adresse for mottaker er ugyldig.</translation> </message> <message> <location line="+5"/> <source>The amount to pay must be larger than 0.</source> <translation>Beløpen som skal betales må være over 0.</translation> </message> <message> <location line="+5"/> <source>The amount exceeds your balance.</source> <translation>Beløpet overstiger saldo.</translation> </message> <message> <location line="+5"/> <source>The total exceeds your balance when the %1 transaction fee is included.</source> <translation>Totalbeløpet overstiger saldo etter at %1 transaksjonsgebyr er lagt til.</translation> </message> <message> <location line="+6"/> <source>Duplicate address found, can only send to each address once per send operation.</source> <translation>Duplikate adresser funnet. Kan bare sende én gang til hver adresse per operasjon.</translation> </message> <message> <location line="+5"/> <source>Error: Transaction creation failed!</source> <translation>Feil: Opprettelse av transaksjon feilet </translation> </message> <message> <location line="+5"/> <source>Error: The transaction was rejected. This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation>Feil: Transaksjonen ble avvist. Dette kan skje om noe av beløpet allerede var brukt, f.eks. hvis du kopierte wallet.dat og noen cypherss ble brukt i kopien men ikke ble markert som brukt her.</translation> </message> </context> <context> <name>SendCoinsEntry</name> <message> <location filename="../forms/sendcoinsentry.ui" line="+14"/> <source>Form</source> <translation>Skjema</translation> </message> <message> <location line="+15"/> <source>A&amp;mount:</source> <translation>&amp;Beløp:</translation> </message> <message> <location line="+13"/> <source>Pay &amp;To:</source> <translation>Betal &amp;Til:</translation> </message> <message> <location line="+34"/> <source>The address to send the payment to (e.g. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation>Adressen betalingen skal sendes til (f.eks. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</translation> </message> <message> <location line="+60"/> <location filename="../sendcoinsentry.cpp" line="+26"/> <source>Enter a label for this address to add it to your address book</source> <translation>Skriv inn en merkelapp for denne adressen for å legge den til i din adressebok</translation> </message> <message> <location line="-78"/> <source>&amp;Label:</source> <translation>&amp;Merkelapp:</translation> </message> <message> <location line="+28"/> <source>Choose address from address book</source> <translation>Velg adresse fra adresseboken</translation> </message> <message> <location line="+10"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="+7"/> <source>Paste address from clipboard</source> <translation>Lim inn adresse fra utklippstavlen</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+7"/> <source>Remove this recipient</source> <translation>Fjern denne mottakeren</translation> </message> <message> <location filename="../sendcoinsentry.cpp" line="+1"/> <source>Enter a cyphers address (e.g. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation>Skriv inn en cyphers adresse (f.eks. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</translation> </message> </context> <context> <name>SignVerifyMessageDialog</name> <message> <location filename="../forms/signverifymessagedialog.ui" line="+14"/> <source>Signatures - Sign / Verify a Message</source> <translation>Signaturer - Signer / Verifiser en melding</translation> </message> <message> <location line="+13"/> <source>&amp;Sign Message</source> <translation>&amp;Signér Melding</translation> </message> <message> <location line="+6"/> <source>You can sign messages with your addresses to prove you own them. Be careful not to sign anything vague, as phishing attacks may try to trick you into signing your identity over to them. Only sign fully-detailed statements you agree to.</source> <translation>Du kan signere meldinger med dine adresser for å bevise at du eier dem. Ikke signér vage meldinger da phishing-angrep kan prøve å lure deg til å signere din identitet over til andre. Signér kun fullt detaljerte utsagn som du er enig i.</translation> </message> <message> <location line="+18"/> <source>The address to sign the message with (e.g. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation>Adressen for signering av meldingen (f.eks. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</translation> </message> <message> <location line="+10"/> <location line="+213"/> <source>Choose an address from the address book</source> <translation>Velg en adresse fra adresseboken</translation> </message> <message> <location line="-203"/> <location line="+213"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="-203"/> <source>Paste address from clipboard</source> <translation>Lim inn adresse fra utklippstavlen</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+12"/> <source>Enter the message you want to sign here</source> <translation>Skriv inn meldingen du vil signere her</translation> </message> <message> <location line="+7"/> <source>Signature</source> <translation type="unfinished"/> </message> <message> <location line="+27"/> <source>Copy the current signature to the system clipboard</source> <translation>Kopier valgt signatur til utklippstavle</translation> </message> <message> <location line="+21"/> <source>Sign the message to prove you own this cyphers address</source> <translation>Signer meldingen for å bevise at du eier denne cyphers-adressen</translation> </message> <message> <location line="+3"/> <source>Sign &amp;Message</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>Reset all sign message fields</source> <translation>Tilbakestill alle felter for meldingssignering</translation> </message> <message> <location line="+3"/> <location line="+146"/> <source>Clear &amp;All</source> <translation>Fjern &amp;Alt</translation> </message> <message> <location line="-87"/> <source>&amp;Verify Message</source> <translation>&amp;Verifiser Melding</translation> </message> <message> <location line="+6"/> <source>Enter the signing address, message (ensure you copy line breaks, spaces, tabs, etc. exactly) and signature below to verify the message. Be careful not to read more into the signature than what is in the signed message itself, to avoid being tricked by a man-in-the-middle attack.</source> <translation>Angi adresse for signering, melding (vær sikker på at du kopierer linjeskift, mellomrom, tab, etc. helt nøyaktig) og signatur under for å verifisere meldingen. Vær forsiktig med at du ikke gir signaturen mer betydning enn det som faktisk står i meldingen, for å unngå å bli lurt av såkalte &quot;man-in-the-middle&quot; angrep.</translation> </message> <message> <location line="+21"/> <source>The address the message was signed with (e.g. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation>Adressen meldingen var signert med (f.eks. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</translation> </message> <message> <location line="+40"/> <source>Verify the message to ensure it was signed with the specified cyphers address</source> <translation>Verifiser meldingen for å være sikker på at den ble signert av den angitte cyphers-adressen</translation> </message> <message> <location line="+3"/> <source>Verify &amp;Message</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>Reset all verify message fields</source> <translation>Tilbakestill alle felter for meldingsverifikasjon</translation> </message> <message> <location filename="../signverifymessagedialog.cpp" line="+27"/> <location line="+3"/> <source>Enter a cyphers address (e.g. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation>Skriv inn en cyphers adresse (f.eks. Ler4HNAEfwYhBmGXcFP2Po1NpRUEiK8km2)</translation> </message> <message> <location line="-2"/> <source>Click &quot;Sign Message&quot; to generate signature</source> <translation>Klikk &quot;Signer Melding&quot; for å generere signatur</translation> </message> <message> <location line="+3"/> <source>Enter cyphers signature</source> <translation>Angi cyphers signatur</translation> </message> <message> <location line="+82"/> <location line="+81"/> <source>The entered address is invalid.</source> <translation>Angitt adresse er ugyldig.</translation> </message> <message> <location line="-81"/> <location line="+8"/> <location line="+73"/> <location line="+8"/> <source>Please check the address and try again.</source> <translation>Vennligst sjekk adressen og prøv igjen.</translation> </message> <message> <location line="-81"/> <location line="+81"/> <source>The entered address does not refer to a key.</source> <translation>Angitt adresse refererer ikke til en nøkkel.</translation> </message> <message> <location line="-73"/> <source>Wallet unlock was cancelled.</source> <translation>Opplåsing av lommebok ble avbrutt.</translation> </message> <message> <location line="+8"/> <source>Private key for the entered address is not available.</source> <translation>Privat nøkkel for den angitte adressen er ikke tilgjengelig.</translation> </message> <message> <location line="+12"/> <source>Message signing failed.</source> <translation>Signering av melding feilet.</translation> </message> <message> <location line="+5"/> <source>Message signed.</source> <translation>Melding signert.</translation> </message> <message> <location line="+59"/> <source>The signature could not be decoded.</source> <translation>Signaturen kunne ikke dekodes.</translation> </message> <message> <location line="+0"/> <location line="+13"/> <source>Please check the signature and try again.</source> <translation>Vennligst sjekk signaturen og prøv igjen.</translation> </message> <message> <location line="+0"/> <source>The signature did not match the message digest.</source> <translation>Signaturen passer ikke til meldingen.</translation> </message> <message> <location line="+7"/> <source>Message verification failed.</source> <translation>Verifikasjon av melding feilet.</translation> </message> <message> <location line="+5"/> <source>Message verified.</source> <translation>Melding verifisert.</translation> </message> </context> <context> <name>SplashScreen</name> <message> <location filename="../splashscreen.cpp" line="+22"/> <source>The cyphers developers</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>[testnet]</source> <translation>[testnett]</translation> </message> </context> <context> <name>TransactionDesc</name> <message> <location filename="../transactiondesc.cpp" line="+20"/> <source>Open until %1</source> <translation>Åpen til %1</translation> </message> <message> <location line="+6"/> <source>%1/offline</source> <translation>%1/frakoblet</translation> </message> <message> <location line="+2"/> <source>%1/unconfirmed</source> <translation>%1/ubekreftet</translation> </message> <message> <location line="+2"/> <source>%1 confirmations</source> <translation>%1 bekreftelser</translation> </message> <message> <location line="+18"/> <source>Status</source> <translation>Status</translation> </message> <message numerus="yes"> <location line="+7"/> <source>, broadcast through %n node(s)</source> <translation><numerusform>, kringkast gjennom %n node</numerusform><numerusform>, kringkast gjennom %n noder</numerusform></translation> </message> <message> <location line="+4"/> <source>Date</source> <translation>Dato</translation> </message> <message> <location line="+7"/> <source>Source</source> <translation>Kilde</translation> </message> <message> <location line="+0"/> <source>Generated</source> <translation>Generert</translation> </message> <message> <location line="+5"/> <location line="+17"/> <source>From</source> <translation>Fra</translation> </message> <message> <location line="+1"/> <location line="+22"/><|fim▁hole|> </message> <message> <location line="-77"/> <location line="+2"/> <source>own address</source> <translation>egen adresse</translation> </message> <message> <location line="-2"/> <source>label</source> <translation>merkelapp</translation> </message> <message> <location line="+37"/> <location line="+12"/> <location line="+45"/> <location line="+17"/> <location line="+30"/> <source>Credit</source> <translation>Kredit</translation> </message> <message numerus="yes"> <location line="-102"/> <source>matures in %n more block(s)</source> <translation><numerusform>blir moden om %n blokk</numerusform><numerusform>blir moden om %n blokker</numerusform></translation> </message> <message> <location line="+2"/> <source>not accepted</source> <translation>ikke akseptert</translation> </message> <message> <location line="+44"/> <location line="+8"/> <location line="+15"/> <location line="+30"/> <source>Debit</source> <translation>Debet</translation> </message> <message> <location line="-39"/> <source>Transaction fee</source> <translation>Transaksjonsgebyr</translation> </message> <message> <location line="+16"/> <source>Net amount</source> <translation>Nettobeløp</translation> </message> <message> <location line="+6"/> <source>Message</source> <translation>Melding</translation> </message> <message> <location line="+2"/> <source>Comment</source> <translation>Kommentar</translation> </message> <message> <location line="+2"/> <source>Transaction ID</source> <translation>Transaksjons-ID</translation> </message> <message> <location line="+3"/> <source>Generated coins must mature 120 blocks before they can be spent. When you generated this block, it was broadcast to the network to be added to the block chain. If it fails to get into the chain, its state will change to &quot;not accepted&quot; and it won&apos;t be spendable. This may occasionally happen if another node generates a block within a few seconds of yours.</source> <translation>Genererte cypherss må modnes 120 blokker før de kan brukes. Da du genererte denne blokken ble den kringkastet til nettverket for å legges til i blokkjeden. Hvis den ikke kommer inn i kjeden får den tilstanden &quot;ikke akseptert&quot; og vil ikke kunne brukes. Dette skjer noen ganger hvis en annen node genererer en blokk noen sekunder fra din.</translation> </message> <message> <location line="+7"/> <source>Debug information</source> <translation>Informasjon for feilsøk</translation> </message> <message> <location line="+8"/> <source>Transaction</source> <translation>Transaksjon</translation> </message> <message> <location line="+3"/> <source>Inputs</source> <translation>Inndata</translation> </message> <message> <location line="+23"/> <source>Amount</source> <translation>Beløp</translation> </message> <message> <location line="+1"/> <source>true</source> <translation>sann</translation> </message> <message> <location line="+0"/> <source>false</source> <translation>usann</translation> </message> <message> <location line="-209"/> <source>, has not been successfully broadcast yet</source> <translation>, har ikke blitt kringkastet uten problemer enda.</translation> </message> <message numerus="yes"> <location line="-35"/> <source>Open for %n more block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+70"/> <source>unknown</source> <translation>ukjent</translation> </message> </context> <context> <name>TransactionDescDialog</name> <message> <location filename="../forms/transactiondescdialog.ui" line="+14"/> <source>Transaction details</source> <translation>Transaksjonsdetaljer</translation> </message> <message> <location line="+6"/> <source>This pane shows a detailed description of the transaction</source> <translation>Her vises en detaljert beskrivelse av transaksjonen</translation> </message> </context> <context> <name>TransactionTableModel</name> <message> <location filename="../transactiontablemodel.cpp" line="+225"/> <source>Date</source> <translation>Dato</translation> </message> <message> <location line="+0"/> <source>Type</source> <translation>Type</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Adresse</translation> </message> <message> <location line="+0"/> <source>Amount</source> <translation>Beløp</translation> </message> <message numerus="yes"> <location line="+57"/> <source>Open for %n more block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+3"/> <source>Open until %1</source> <translation>Åpen til %1</translation> </message> <message> <location line="+3"/> <source>Offline (%1 confirmations)</source> <translation>Frakoblet (%1 bekreftelser)</translation> </message> <message> <location line="+3"/> <source>Unconfirmed (%1 of %2 confirmations)</source> <translation>Ubekreftet (%1 av %2 bekreftelser)</translation> </message> <message> <location line="+3"/> <source>Confirmed (%1 confirmations)</source> <translation>Bekreftet (%1 bekreftelser)</translation> </message> <message numerus="yes"> <location line="+8"/> <source>Mined balance will be available when it matures in %n more block(s)</source> <translation><numerusform>Minet saldo blir tilgjengelig når den modner om %n blokk</numerusform><numerusform>Minet saldo blir tilgjengelig når den modner om %n blokker</numerusform></translation> </message> <message> <location line="+5"/> <source>This block was not received by any other nodes and will probably not be accepted!</source> <translation>Denne blokken har ikke blitt mottatt av noen andre noder og vil sannsynligvis ikke bli akseptert!</translation> </message> <message> <location line="+3"/> <source>Generated but not accepted</source> <translation>Generert men ikke akseptert</translation> </message> <message> <location line="+43"/> <source>Received with</source> <translation>Mottatt med</translation> </message> <message> <location line="+2"/> <source>Received from</source> <translation>Mottatt fra</translation> </message> <message> <location line="+3"/> <source>Sent to</source> <translation>Sendt til</translation> </message> <message> <location line="+2"/> <source>Payment to yourself</source> <translation>Betaling til deg selv</translation> </message> <message> <location line="+2"/> <source>Mined</source> <translation>Utvunnet</translation> </message> <message> <location line="+38"/> <source>(n/a)</source> <translation>-</translation> </message> <message> <location line="+199"/> <source>Transaction status. Hover over this field to show number of confirmations.</source> <translation>Transaksjonsstatus. Hold muspekeren over dette feltet for å se antall bekreftelser.</translation> </message> <message> <location line="+2"/> <source>Date and time that the transaction was received.</source> <translation>Dato og tid for da transaksjonen ble mottat.</translation> </message> <message> <location line="+2"/> <source>Type of transaction.</source> <translation>Type transaksjon.</translation> </message> <message> <location line="+2"/> <source>Destination address of transaction.</source> <translation>Mottaksadresse for transaksjonen</translation> </message> <message> <location line="+2"/> <source>Amount removed from or added to balance.</source> <translation>Beløp fjernet eller lagt til saldo.</translation> </message> </context> <context> <name>TransactionView</name> <message> <location filename="../transactionview.cpp" line="+52"/> <location line="+16"/> <source>All</source> <translation>Alle</translation> </message> <message> <location line="-15"/> <source>Today</source> <translation>I dag</translation> </message> <message> <location line="+1"/> <source>This week</source> <translation>Denne uken</translation> </message> <message> <location line="+1"/> <source>This month</source> <translation>Denne måneden</translation> </message> <message> <location line="+1"/> <source>Last month</source> <translation>Forrige måned</translation> </message> <message> <location line="+1"/> <source>This year</source> <translation>Dette året</translation> </message> <message> <location line="+1"/> <source>Range...</source> <translation>Intervall...</translation> </message> <message> <location line="+11"/> <source>Received with</source> <translation>Mottatt med</translation> </message> <message> <location line="+2"/> <source>Sent to</source> <translation>Sendt til</translation> </message> <message> <location line="+2"/> <source>To yourself</source> <translation>Til deg selv</translation> </message> <message> <location line="+1"/> <source>Mined</source> <translation>Utvunnet</translation> </message> <message> <location line="+1"/> <source>Other</source> <translation>Andre</translation> </message> <message> <location line="+7"/> <source>Enter address or label to search</source> <translation>Skriv inn adresse eller merkelapp for søk</translation> </message> <message> <location line="+7"/> <source>Min amount</source> <translation>Minimumsbeløp</translation> </message> <message> <location line="+34"/> <source>Copy address</source> <translation>Kopier adresse</translation> </message> <message> <location line="+1"/> <source>Copy label</source> <translation>Kopier merkelapp</translation> </message> <message> <location line="+1"/> <source>Copy amount</source> <translation>Kopiér beløp</translation> </message> <message> <location line="+1"/> <source>Copy transaction ID</source> <translation>Kopier transaksjons-ID</translation> </message> <message> <location line="+1"/> <source>Edit label</source> <translation>Rediger merkelapp</translation> </message> <message> <location line="+1"/> <source>Show transaction details</source> <translation>Vis transaksjonsdetaljer</translation> </message> <message> <location line="+139"/> <source>Export Transaction Data</source> <translation>Eksporter transaksjonsdata</translation> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Kommaseparert fil (*.csv)</translation> </message> <message> <location line="+8"/> <source>Confirmed</source> <translation>Bekreftet</translation> </message> <message> <location line="+1"/> <source>Date</source> <translation>Dato</translation> </message> <message> <location line="+1"/> <source>Type</source> <translation>Type</translation> </message> <message> <location line="+1"/> <source>Label</source> <translation>Merkelapp</translation> </message> <message> <location line="+1"/> <source>Address</source> <translation>Adresse</translation> </message> <message> <location line="+1"/> <source>Amount</source> <translation>Beløp</translation> </message> <message> <location line="+1"/> <source>ID</source> <translation>ID</translation> </message> <message> <location line="+4"/> <source>Error exporting</source> <translation>Feil ved eksport</translation> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation>Kunne ikke skrive til filen %1.</translation> </message> <message> <location line="+100"/> <source>Range:</source> <translation>Intervall:</translation> </message> <message> <location line="+8"/> <source>to</source> <translation>til</translation> </message> </context> <context> <name>WalletModel</name> <message> <location filename="../walletmodel.cpp" line="+193"/> <source>Send Coins</source> <translation>Send cypherss</translation> </message> </context> <context> <name>WalletView</name> <message> <location filename="../walletview.cpp" line="+42"/> <source>&amp;Export</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Export the data in the current tab to a file</source> <translation>Eksporter data fra nåværende fane til fil</translation> </message> <message> <location line="+193"/> <source>Backup Wallet</source> <translation>Sikkerhetskopier lommebok</translation> </message> <message> <location line="+0"/> <source>Wallet Data (*.dat)</source> <translation>Lommebokdata (*.dat)</translation> </message> <message> <location line="+3"/> <source>Backup Failed</source> <translation>Sikkerhetskopiering feilet</translation> </message> <message> <location line="+0"/> <source>There was an error trying to save the wallet data to the new location.</source> <translation>En feil oppstod under lagringen av lommeboken til den nye plasseringen.</translation> </message> <message> <location line="+4"/> <source>Backup Successful</source> <translation>Sikkerhetskopiering fullført</translation> </message> <message> <location line="+0"/> <source>The wallet data was successfully saved to the new location.</source> <translation>Lommebokdata ble lagret til den nye plasseringen. </translation> </message> </context> <context> <name>bitcoin-core</name> <message> <location filename="../bitcoinstrings.cpp" line="+94"/> <source>cyphers version</source> <translation>cyphers versjon</translation> </message> <message> <location line="+102"/> <source>Usage:</source> <translation>Bruk:</translation> </message> <message> <location line="-29"/> <source>Send command to -server or cyphersd</source> <translation>Send kommando til -server eller cyphersd</translation> </message> <message> <location line="-23"/> <source>List commands</source> <translation>List opp kommandoer</translation> </message> <message> <location line="-12"/> <source>Get help for a command</source> <translation>Vis hjelpetekst for en kommando</translation> </message> <message> <location line="+24"/> <source>Options:</source> <translation>Innstillinger:</translation> </message> <message> <location line="+24"/> <source>Specify configuration file (default: cyphers.conf)</source> <translation>Angi konfigurasjonsfil (standardverdi: cyphers.conf)</translation> </message> <message> <location line="+3"/> <source>Specify pid file (default: cyphersd.pid)</source> <translation>Angi pid-fil (standardverdi: cyphersd.pid)</translation> </message> <message> <location line="-1"/> <source>Specify data directory</source> <translation>Angi mappe for datafiler</translation> </message> <message> <location line="-9"/> <source>Set database cache size in megabytes (default: 25)</source> <translation>Sett størrelse på mellomlager for database i megabytes (standardverdi: 25)</translation> </message> <message> <location line="-28"/> <source>Listen for connections on &lt;port&gt; (default: 9333 or testnet: 19333)</source> <translation>Lytt etter tilkoblinger på &lt;port&gt; (standardverdi: 9333 eller testnet: 19333)</translation> </message> <message> <location line="+5"/> <source>Maintain at most &lt;n&gt; connections to peers (default: 125)</source> <translation>Hold maks &lt;n&gt; koblinger åpne til andre noder (standardverdi: 125)</translation> </message> <message> <location line="-48"/> <source>Connect to a node to retrieve peer addresses, and disconnect</source> <translation>Koble til node for å hente adresser til andre noder, koble så fra igjen</translation> </message> <message> <location line="+82"/> <source>Specify your own public address</source> <translation>Angi din egen offentlige adresse</translation> </message> <message> <location line="+3"/> <source>Threshold for disconnecting misbehaving peers (default: 100)</source> <translation>Grenseverdi for å koble fra noder med dårlig oppførsel (standardverdi: 100)</translation> </message> <message> <location line="-134"/> <source>Number of seconds to keep misbehaving peers from reconnecting (default: 86400)</source> <translation>Antall sekunder noder med dårlig oppførsel hindres fra å koble til på nytt (standardverdi: 86400)</translation> </message> <message> <location line="-29"/> <source>An error occurred while setting up the RPC port %u for listening on IPv4: %s</source> <translation>En feil oppstod ved opprettelse av RPC port %u for lytting: %s</translation> </message> <message> <location line="+27"/> <source>Listen for JSON-RPC connections on &lt;port&gt; (default: 9332 or testnet: 19332)</source> <translation>Lytt etter JSON-RPC tilkoblinger på &lt;port&gt; (standardverdi: 9332 or testnet: 19332)</translation> </message> <message> <location line="+37"/> <source>Accept command line and JSON-RPC commands</source> <translation>Ta imot kommandolinje- og JSON-RPC-kommandoer</translation> </message> <message> <location line="+76"/> <source>Run in the background as a daemon and accept commands</source> <translation>Kjør i bakgrunnen som daemon og ta imot kommandoer</translation> </message> <message> <location line="+37"/> <source>Use the test network</source> <translation>Bruk testnettverket</translation> </message> <message> <location line="-112"/> <source>Accept connections from outside (default: 1 if no -proxy or -connect)</source> <translation>Ta imot tilkoblinger fra utsiden (standardverdi: 1 hvis uten -proxy eller -connect)</translation> </message> <message> <location line="-80"/> <source>%s, you must set a rpcpassword in the configuration file: %s It is recommended you use the following random password: rpcuser=cyphersrpc rpcpassword=%s (you do not need to remember this password) The username and password MUST NOT be the same. If the file does not exist, create it with owner-readable-only file permissions. It is also recommended to set alertnotify so you are notified of problems; for example: alertnotify=echo %%s | mail -s &quot;cyphers Alert&quot; [email protected] </source> <translation>%s, du må angi rpcpassord i konfigurasjonsfilen. %s Det anbefales at du bruker det følgende tilfeldige passordet: rpcbruker=cyphersrpc rpcpassord=%s (du behøver ikke å huske passordet) Brukernavnet og passordet MÅ IKKE være like. Om filen ikke eksisterer, opprett den nå med eier-kun-les filrettigheter. Det er også anbefalt at å sette varselsmelding slik du får melding om problemer. For eksempel: varselmelding=echo %%s | mail -s &quot;cyphers varsel&quot; [email protected]</translation> </message> <message> <location line="+17"/> <source>An error occurred while setting up the RPC port %u for listening on IPv6, falling back to IPv4: %s</source> <translation>En feil oppstod under oppsettet av RPC port %u for IPv6, tilbakestilles til IPv4: %s</translation> </message> <message> <location line="+3"/> <source>Bind to given address and always listen on it. Use [host]:port notation for IPv6</source> <translation>Bind til angitt adresse. Bruk [vertsmaskin]:port notasjon for IPv6</translation> </message> <message> <location line="+3"/> <source>Cannot obtain a lock on data directory %s. cyphers is probably already running.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Error: The transaction was rejected! This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Error: This transaction requires a transaction fee of at least %s because of its amount, complexity, or use of recently received funds!</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Execute command when a relevant alert is received (%s in cmd is replaced by message)</source> <translation>Kjør kommando når relevant varsel blir mottatt (%s i cmd er erstattet med TxID)</translation> </message> <message> <location line="+3"/> <source>Execute command when a wallet transaction changes (%s in cmd is replaced by TxID)</source> <translation>Kjør kommando når en lommeboktransaksjon endres (%s i cmd er erstattet med TxID)</translation> </message> <message> <location line="+11"/> <source>Set maximum size of high-priority/low-fee transactions in bytes (default: 27000)</source> <translation>Sett maks størrelse for transaksjoner med høy prioritet / lavt gebyr, i bytes (standardverdi: 27000)</translation> </message> <message> <location line="+6"/> <source>This is a pre-release test build - use at your own risk - do not use for mining or merchant applications</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Warning: -paytxfee is set very high! This is the transaction fee you will pay if you send a transaction.</source> <translation>Advarsel: -paytxfee er satt veldig høyt! Dette er transaksjonsgebyret du betaler når du sender transaksjoner.</translation> </message> <message> <location line="+3"/> <source>Warning: Displayed transactions may not be correct! You may need to upgrade, or other nodes may need to upgrade.</source> <translation>Advarsel: Viste transaksjoner kan være feil! Du, eller andre noder, kan trenge en oppgradering.</translation> </message> <message> <location line="+3"/> <source>Warning: Please check that your computer&apos;s date and time are correct! If your clock is wrong cyphers will not work properly.</source> <translation>Advarsel: Vennligst undersøk at din datamaskin har riktig dato og klokkeslett! Hvis klokken er stilt feil vil ikke cyphers fungere riktig.</translation> </message> <message> <location line="+3"/> <source>Warning: error reading wallet.dat! All keys read correctly, but transaction data or address book entries might be missing or incorrect.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Warning: wallet.dat corrupt, data salvaged! Original wallet.dat saved as wallet.{timestamp}.bak in %s; if your balance or transactions are incorrect you should restore from a backup.</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>Attempt to recover private keys from a corrupt wallet.dat</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Block creation options:</source> <translation>Valg for opprettelse av blokker:</translation> </message> <message> <location line="+5"/> <source>Connect only to the specified node(s)</source> <translation>Koble kun til angitt(e) node(r)</translation> </message> <message> <location line="+3"/> <source>Corrupted block database detected</source> <translation>Oppdaget korrupt blokkdatabase</translation> </message> <message> <location line="+1"/> <source>Discover own IP address (default: 1 when listening and no -externalip)</source> <translation>Oppdag egen IP-adresse (standardverdi: 1 ved lytting og uten -externalip)</translation> </message> <message> <location line="+1"/> <source>Do you want to rebuild the block database now?</source> <translation>Ønsker du å gjenopprette blokkdatabasen nå?</translation> </message> <message> <location line="+2"/> <source>Error initializing block database</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Error initializing wallet database environment %s!</source> <translation>Feil under oppstart av lommebokdatabasemiljø %s!</translation> </message> <message> <location line="+1"/> <source>Error loading block database</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Error opening block database</source> <translation>Feil under åpning av blokkdatabase</translation> </message> <message> <location line="+2"/> <source>Error: Disk space is low!</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Error: Wallet locked, unable to create transaction!</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Error: system error: </source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to listen on any port. Use -listen=0 if you want this.</source> <translation>Kunne ikke lytte på noen port. Bruk -listen=0 hvis det er dette du vil.</translation> </message> <message> <location line="+1"/> <source>Failed to read block info</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to read block</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to sync block index</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write block index</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write block info</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write block</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write file info</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write to coin database</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write transaction index</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Failed to write undo data</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Find peers using DNS lookup (default: 1 unless -connect)</source> <translation>Finn andre noder gjennom DNS-oppslag (standardverdi: 1 med mindre -connect er oppgit)</translation> </message> <message> <location line="+1"/> <source>Generate coins (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>How many blocks to check at startup (default: 288, 0 = all)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>How thorough the block verification is (0-4, default: 3)</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>Not enough file descriptors available.</source> <translation type="unfinished"/> </message> <message> <location line="+8"/> <source>Rebuild block chain index from current blk000??.dat files</source> <translation>Gjenopprett blokkjedeindex fra blk000??.dat filer</translation> </message> <message> <location line="+16"/> <source>Set the number of threads to service RPC calls (default: 4)</source> <translation type="unfinished"/> </message> <message> <location line="+26"/> <source>Verifying blocks...</source> <translation>Verifiserer blokker...</translation> </message> <message> <location line="+1"/> <source>Verifying wallet...</source> <translation>Verifiserer lommebok...</translation> </message> <message> <location line="-69"/> <source>Imports blocks from external blk000??.dat file</source> <translation type="unfinished"/> </message> <message> <location line="-76"/> <source>Set the number of script verification threads (up to 16, 0 = auto, &lt;0 = leave that many cores free, default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+77"/> <source>Information</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Invalid -tor address: &apos;%s&apos;</source> <translation>Ugyldig -tor adresse: &apos;%s&apos;</translation> </message> <message> <location line="+1"/> <source>Invalid amount for -minrelaytxfee=&lt;amount&gt;: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Invalid amount for -mintxfee=&lt;amount&gt;: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+8"/> <source>Maintain a full transaction index (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Maximum per-connection receive buffer, &lt;n&gt;*1000 bytes (default: 5000)</source> <translation>Maks mottaksbuffer per forbindelse, &lt;n&gt;*1000 bytes (standardverdi: 5000)</translation> </message> <message> <location line="+1"/> <source>Maximum per-connection send buffer, &lt;n&gt;*1000 bytes (default: 1000)</source> <translation>Maks sendebuffer per forbindelse, &lt;n&gt;*1000 bytes (standardverdi: 1000)</translation> </message> <message> <location line="+2"/> <source>Only accept block chain matching built-in checkpoints (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Only connect to nodes in network &lt;net&gt; (IPv4, IPv6 or Tor)</source> <translation>Koble kun til noder i nettverket &lt;nett&gt; (IPv4, IPv6 eller Tor)</translation> </message> <message> <location line="+2"/> <source>Output extra debugging information. Implies all other -debug* options</source> <translation>Skriv ekstra informasjon for feilsøk. Medfører at alle -debug* valg tas med</translation> </message> <message> <location line="+1"/> <source>Output extra network debugging information</source> <translation>Skriv ekstra informasjon for feilsøk av nettverk</translation> </message> <message> <location line="+2"/> <source>Prepend debug output with timestamp</source> <translation>Sett tidsstempel på debugmeldinger</translation> </message> <message> <location line="+5"/> <source>SSL options: (see the cyphers Wiki for SSL setup instructions)</source> <translation>SSL valg: (se cyphers Wiki for instruksjoner for oppsett av SSL)</translation> </message> <message> <location line="+1"/> <source>Select the version of socks proxy to use (4-5, default: 5)</source> <translation>Velg versjon av socks proxy (4-5, standardverdi 5)</translation> </message> <message> <location line="+3"/> <source>Send trace/debug info to console instead of debug.log file</source> <translation>Send spor/debug informasjon til konsollet istedenfor debug.log filen</translation> </message> <message> <location line="+1"/> <source>Send trace/debug info to debugger</source> <translation>Send spor/debug informasjon til debugger</translation> </message> <message> <location line="+5"/> <source>Set maximum block size in bytes (default: 250000)</source> <translation>Sett maks blokkstørrelse i bytes (standardverdi: 250000)</translation> </message> <message> <location line="+1"/> <source>Set minimum block size in bytes (default: 0)</source> <translation>Sett minimum blokkstørrelse i bytes (standardverdi: 0)</translation> </message> <message> <location line="+2"/> <source>Shrink debug.log file on client startup (default: 1 when no -debug)</source> <translation>Krymp debug.log filen når klienten starter (standardverdi: 1 hvis uten -debug)</translation> </message> <message> <location line="+1"/> <source>Signing transaction failed</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Specify connection timeout in milliseconds (default: 5000)</source> <translation>Angi tidsavbrudd for forbindelse i millisekunder (standardverdi: 5000)</translation> </message> <message> <location line="+4"/> <source>System error: </source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Transaction amount too small</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Transaction amounts must be positive</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Transaction too large</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Use UPnP to map the listening port (default: 0)</source> <translation>Bruk UPnP for lytteport (standardverdi: 0)</translation> </message> <message> <location line="+1"/> <source>Use UPnP to map the listening port (default: 1 when listening)</source> <translation>Bruk UPnP for lytteport (standardverdi: 1 ved lytting)</translation> </message> <message> <location line="+1"/> <source>Use proxy to reach tor hidden services (default: same as -proxy)</source> <translation>Bruk en proxy for å nå skjulte tor tjenester (standardverdi: samme som -proxy)</translation> </message> <message> <location line="+2"/> <source>Username for JSON-RPC connections</source> <translation>Brukernavn for JSON-RPC forbindelser</translation> </message> <message> <location line="+4"/> <source>Warning</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Warning: This version is obsolete, upgrade required!</source> <translation>Advarsel: Denne versjonen er foreldet, oppgradering kreves!</translation> </message> <message> <location line="+1"/> <source>You need to rebuild the databases using -reindex to change -txindex</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>wallet.dat corrupt, salvage failed</source> <translation type="unfinished"/> </message> <message> <location line="-50"/> <source>Password for JSON-RPC connections</source> <translation>Passord for JSON-RPC forbindelser</translation> </message> <message> <location line="-67"/> <source>Allow JSON-RPC connections from specified IP address</source> <translation>Tillat JSON-RPC tilkoblinger fra angitt IP-adresse</translation> </message> <message> <location line="+76"/> <source>Send commands to node running on &lt;ip&gt; (default: 127.0.0.1)</source> <translation>Send kommandoer til node på &lt;ip&gt; (standardverdi: 127.0.0.1)</translation> </message> <message> <location line="-120"/> <source>Execute command when the best block changes (%s in cmd is replaced by block hash)</source> <translation>Eksekvér kommando når beste blokk endrer seg (%s i kommandoen erstattes med blokkens hash)</translation> </message> <message> <location line="+147"/> <source>Upgrade wallet to latest format</source> <translation>Oppgradér lommebok til nyeste format</translation> </message> <message> <location line="-21"/> <source>Set key pool size to &lt;n&gt; (default: 100)</source> <translation>Angi størrelse på nøkkel-lager til &lt;n&gt; (standardverdi: 100)</translation> </message> <message> <location line="-12"/> <source>Rescan the block chain for missing wallet transactions</source> <translation>Se gjennom blokk-kjeden etter manglende lommeboktransaksjoner</translation> </message> <message> <location line="+35"/> <source>Use OpenSSL (https) for JSON-RPC connections</source> <translation>Bruk OpenSSL (https) for JSON-RPC forbindelser</translation> </message> <message> <location line="-26"/> <source>Server certificate file (default: server.cert)</source> <translation>Servers sertifikat (standardverdi: server.cert)</translation> </message> <message> <location line="+1"/> <source>Server private key (default: server.pem)</source> <translation>Servers private nøkkel (standardverdi: server.pem)</translation> </message> <message> <location line="-151"/> <source>Acceptable ciphers (default: TLSv1+HIGH:!SSLv2:!aNULL:!eNULL:!AH:!3DES:@STRENGTH)</source> <translation>Akseptable krypteringsmetoder (standardverdi: TLSv1+HIGH:!SSLv2:!aNULL:!eNULL:!AH:!3DES:@STRENGTH)</translation> </message> <message> <location line="+165"/> <source>This help message</source> <translation>Denne hjelpemeldingen</translation> </message> <message> <location line="+6"/> <source>Unable to bind to %s on this computer (bind returned error %d, %s)</source> <translation>Kan ikke binde til %s på denne datamaskinen (bind returnerte feil %d, %s)</translation> </message> <message> <location line="-91"/> <source>Connect through socks proxy</source> <translation>Koble til gjennom socks proxy</translation> </message> <message> <location line="-10"/> <source>Allow DNS lookups for -addnode, -seednode and -connect</source> <translation>Tillat DNS oppslag for -addnode, -seednode og -connect</translation> </message> <message> <location line="+55"/> <source>Loading addresses...</source> <translation>Laster adresser...</translation> </message> <message> <location line="-35"/> <source>Error loading wallet.dat: Wallet corrupted</source> <translation>Feil ved lasting av wallet.dat: Lommeboken er skadet</translation> </message> <message> <location line="+1"/> <source>Error loading wallet.dat: Wallet requires newer version of cyphers</source> <translation>Feil ved lasting av wallet.dat: Lommeboken krever en nyere versjon av cyphers</translation> </message> <message> <location line="+93"/> <source>Wallet needed to be rewritten: restart cyphers to complete</source> <translation>Lommeboken måtte skrives om: start cyphers på nytt for å fullføre</translation> </message> <message> <location line="-95"/> <source>Error loading wallet.dat</source> <translation>Feil ved lasting av wallet.dat</translation> </message> <message> <location line="+28"/> <source>Invalid -proxy address: &apos;%s&apos;</source> <translation>Ugyldig -proxy adresse: &apos;%s&apos;</translation> </message> <message> <location line="+56"/> <source>Unknown network specified in -onlynet: &apos;%s&apos;</source> <translation>Ukjent nettverk angitt i -onlynet &apos;%s&apos;</translation> </message> <message> <location line="-1"/> <source>Unknown -socks proxy version requested: %i</source> <translation>Ukjent -socks proxy versjon angitt: %i</translation> </message> <message> <location line="-96"/> <source>Cannot resolve -bind address: &apos;%s&apos;</source> <translation>Kunne ikke slå opp -bind adresse: &apos;%s&apos;</translation> </message> <message> <location line="+1"/> <source>Cannot resolve -externalip address: &apos;%s&apos;</source> <translation>Kunne ikke slå opp -externalip adresse: &apos;%s&apos;</translation> </message> <message> <location line="+44"/> <source>Invalid amount for -paytxfee=&lt;amount&gt;: &apos;%s&apos;</source> <translation>Ugyldig beløp for -paytxfee=&lt;beløp&gt;: &apos;%s&apos;</translation> </message> <message> <location line="+1"/> <source>Invalid amount</source> <translation>Ugyldig beløp</translation> </message> <message> <location line="-6"/> <source>Insufficient funds</source> <translation>Utilstrekkelige midler</translation> </message> <message> <location line="+10"/> <source>Loading block index...</source> <translation>Laster blokkindeks...</translation> </message> <message> <location line="-57"/> <source>Add a node to connect to and attempt to keep the connection open</source> <translation>Legg til node for tilkobling og hold forbindelsen åpen</translation> </message> <message> <location line="-25"/> <source>Unable to bind to %s on this computer. cyphers is probably already running.</source> <translation>Kan ikke binde til %s på denne datamaskinen. Sannsynligvis kjører cyphers allerede.</translation> </message> <message> <location line="+64"/> <source>Fee per KB to add to transactions you send</source> <translation>Gebyr per KB for transaksjoner du sender</translation> </message> <message> <location line="+19"/> <source>Loading wallet...</source> <translation>Laster lommebok...</translation> </message> <message> <location line="-52"/> <source>Cannot downgrade wallet</source> <translation>Kan ikke nedgradere lommebok</translation> </message> <message> <location line="+3"/> <source>Cannot write default address</source> <translation>Kan ikke skrive standardadresse</translation> </message> <message> <location line="+64"/> <source>Rescanning...</source> <translation>Leser gjennom...</translation> </message> <message> <location line="-57"/> <source>Done loading</source> <translation>Ferdig med lasting</translation> </message> <message> <location line="+82"/> <source>To use the %s option</source> <translation>For å bruke %s opsjonen</translation> </message> <message> <location line="-74"/> <source>Error</source> <translation>Feil</translation> </message> <message> <location line="-31"/> <source>You must set rpcpassword=&lt;password&gt; in the configuration file: %s If the file does not exist, create it with owner-readable-only file permissions.</source> <translation>Du må sette rpcpassword=&lt;passord&gt; i konfigurasjonsfilen: %s Hvis filen ikke finnes, opprett den med leserettighet kun for eier av filen.</translation> </message> </context> </TS><|fim▁end|>
<location line="+58"/> <source>To</source> <translation>Til</translation>
<|file_name|>index.js<|end_file_name|><|fim▁begin|><|fim▁hole|>}; export default IIcon;<|fim▁end|>
export const IIcon = { name: 'i-icon',
<|file_name|>bitcoin_pt_PT.ts<|end_file_name|><|fim▁begin|><?xml version="1.0" ?><!DOCTYPE TS><TS language="pt_PT" version="2.1"> <context> <name>AboutDialog</name> <message> <location filename="../forms/aboutdialog.ui" line="+14"/> <source>About bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+39"/> <source>&lt;b&gt;bitcoinlite&lt;/b&gt; version</source> <translation type="unfinished"/> </message> <message> <location line="+41"/> <source>Copyright © 2009-2014 The Bitcoin developers Copyright © 2012-2014 The NovaCoin developers Copyright © 2014 The bitcoinlite developers</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source> This is experimental software. Distributed under the MIT/X11 software license, see the accompanying file COPYING or http://www.opensource.org/licenses/mit-license.php. This product includes software developed by the OpenSSL Project for use in the OpenSSL Toolkit (http://www.openssl.org/) and cryptographic software written by Eric Young ([email protected]) and UPnP software written by Thomas Bernard.</source> <translation> Este é um programa experimental. Distribuído sob uma licença de software MIT/X11, por favor verifique o ficheiro anexo license.txt ou http://www.opensource.org/licenses/mit-license.php. Este produto inclui software desenvolvido pelo Projecto OpenSSL para uso no OpenSSL Toolkit (http://www.openssl.org/), software criptográfico escrito por Eric Young ([email protected]) e software UPnP escrito por Thomas Bernard.</translation> </message> </context> <context> <name>AddressBookPage</name> <message> <location filename="../forms/addressbookpage.ui" line="+14"/> <source>Address Book</source> <translation type="unfinished"/> </message> <message> <location line="+22"/> <source>Double-click to edit address or label</source> <translation>Clique duas vezes para editar o endereço ou o rótulo</translation> </message> <message> <location line="+27"/> <source>Create a new address</source> <translation>Criar um novo endereço</translation> </message> <message> <location line="+14"/> <source>Copy the currently selected address to the system clipboard</source> <translation>Copie o endereço selecionado para a área de transferência</translation> </message> <message> <location line="-11"/> <source>&amp;New Address</source> <translation type="unfinished"/> </message> <message> <location line="-46"/> <source>These are your bitcoinlite addresses for receiving payments. You may want to give a different one to each sender so you can keep track of who is paying you.</source> <translation type="unfinished"/> </message> <message> <location line="+60"/> <source>&amp;Copy Address</source> <translation>&amp;Copiar Endereço</translation> </message> <message> <location line="+11"/> <source>Show &amp;QR Code</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Sign a message to prove you own a bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Sign &amp;Message</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Delete the currently selected address from the list</source> <translation>Apagar o endereço selecionado da lista</translation> </message> <message> <location line="-14"/> <source>Verify a message to ensure it was signed with a specified bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Verify Message</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>&amp;Delete</source> <translation>E&amp;liminar</translation> </message> <message> <location filename="../addressbookpage.cpp" line="+65"/> <source>Copy &amp;Label</source> <translation>Copiar &amp;Rótulo</translation> </message> <message> <location line="+2"/> <source>&amp;Edit</source> <translation>&amp;Editar</translation> </message> <message> <location line="+250"/> <source>Export Address Book Data</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Ficheiro separado por vírgulas (*.csv)</translation> </message> <message> <location line="+13"/> <source>Error exporting</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation type="unfinished"/> </message> </context> <context> <name>AddressTableModel</name> <message> <location filename="../addresstablemodel.cpp" line="+144"/> <source>Label</source> <translation>Rótulo</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Endereço</translation> </message> <message> <location line="+36"/> <source>(no label)</source> <translation>(sem rótulo)</translation> </message> </context> <context> <name>AskPassphraseDialog</name> <message> <location filename="../forms/askpassphrasedialog.ui" line="+26"/> <source>Passphrase Dialog</source> <translation>Diálogo de Frase-Passe</translation> </message> <message> <location line="+21"/> <source>Enter passphrase</source> <translation>Escreva a frase de segurança</translation> </message> <message> <location line="+14"/> <source>New passphrase</source> <translation>Nova frase de segurança</translation> </message> <message> <location line="+14"/> <source>Repeat new passphrase</source> <translation>Repita a nova frase de segurança</translation> </message> <message> <location line="+33"/> <source>Serves to disable the trivial sendmoney when OS account compromised. Provides no real security.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>For staking only</source> <translation type="unfinished"/> </message> <message> <location filename="../askpassphrasedialog.cpp" line="+35"/> <source>Enter the new passphrase to the wallet.&lt;br/&gt;Please use a passphrase of &lt;b&gt;10 or more random characters&lt;/b&gt;, or &lt;b&gt;eight or more words&lt;/b&gt;.</source> <translation>Escreva a nova frase de seguraça da sua carteira. &lt;br/&gt; Por favor, use uma frase de &lt;b&gt;10 ou mais caracteres aleatórios,&lt;/b&gt; ou &lt;b&gt;oito ou mais palavras&lt;/b&gt;.</translation> </message> <message> <location line="+1"/> <source>Encrypt wallet</source> <translation>Encriptar carteira</translation> </message> <message> <location line="+7"/> <source>This operation needs your wallet passphrase to unlock the wallet.</source> <translation>A sua frase de segurança é necessária para desbloquear a carteira.</translation> </message> <message> <location line="+5"/> <source>Unlock wallet</source> <translation>Desbloquear carteira</translation> </message> <message> <location line="+3"/> <source>This operation needs your wallet passphrase to decrypt the wallet.</source> <translation>A sua frase de segurança é necessária para desencriptar a carteira.</translation> </message> <message> <location line="+5"/> <source>Decrypt wallet</source> <translation>Desencriptar carteira</translation> </message> <message> <location line="+3"/> <source>Change passphrase</source> <translation>Alterar frase de segurança</translation> </message> <message> <location line="+1"/> <source>Enter the old and new passphrase to the wallet.</source> <translation>Escreva a frase de segurança antiga seguida da nova para a carteira.</translation> </message> <message> <location line="+46"/> <source>Confirm wallet encryption</source> <translation>Confirmar encriptação da carteira</translation> </message> <message> <location line="+1"/> <source>Warning: If you encrypt your wallet and lose your passphrase, you will &lt;b&gt;LOSE ALL OF YOUR COINS&lt;/b&gt;!</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Are you sure you wish to encrypt your wallet?</source> <translation>Tem a certeza que deseja encriptar a carteira?</translation> </message> <message> <location line="+15"/> <source>IMPORTANT: Any previous backups you have made of your wallet file should be replaced with the newly generated, encrypted wallet file. For security reasons, previous backups of the unencrypted wallet file will become useless as soon as you start using the new, encrypted wallet.</source> <translation>IMPORTANTE: Qualquer cópia de segurança anterior da carteira deverá ser substituída com o novo, actualmente encriptado, ficheiro de carteira. Por razões de segurança, cópias de segurança não encriptadas efectuadas anteriormente do ficheiro da carteira tornar-se-ão inúteis assim que começar a usar a nova carteira encriptada.</translation> </message> <message> <location line="+103"/> <location line="+24"/> <source>Warning: The Caps Lock key is on!</source> <translation>Atenção: A tecla Caps Lock está activa!</translation> </message> <message> <location line="-133"/> <location line="+60"/> <source>Wallet encrypted</source> <translation>Carteira encriptada</translation> </message> <message> <location line="-58"/> <source>bitcoinlite will close now to finish the encryption process. Remember that encrypting your wallet cannot fully protect your coins from being stolen by malware infecting your computer.</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <location line="+7"/> <location line="+44"/> <location line="+6"/> <source>Wallet encryption failed</source> <translation>A encriptação da carteira falhou</translation> </message> <message> <location line="-56"/> <source>Wallet encryption failed due to an internal error. Your wallet was not encrypted.</source> <translation>A encriptação da carteira falhou devido a um erro interno. A carteira não foi encriptada.</translation> </message> <message> <location line="+7"/> <location line="+50"/> <source>The supplied passphrases do not match.</source> <translation>As frases de segurança fornecidas não coincidem.</translation> </message> <message> <location line="-38"/> <source>Wallet unlock failed</source> <translation>O desbloqueio da carteira falhou</translation> </message> <message> <location line="+1"/> <location line="+12"/> <location line="+19"/> <source>The passphrase entered for the wallet decryption was incorrect.</source> <translation>A frase de segurança introduzida para a desencriptação da carteira estava incorreta.</translation> </message> <message> <location line="-20"/> <source>Wallet decryption failed</source> <translation>A desencriptação da carteira falhou</translation> </message> <message> <location line="+14"/> <source>Wallet passphrase was successfully changed.</source> <translation>A frase de segurança da carteira foi alterada com êxito.</translation> </message> </context> <context> <name>BitcoinGUI</name> <message> <location filename="../bitcoingui.cpp" line="+280"/> <source>Sign &amp;message...</source> <translation>Assinar &amp;mensagem...</translation> </message> <message> <location line="+242"/> <source>Synchronizing with network...</source> <translation>Sincronizando com a rede...</translation> </message> <message> <location line="-308"/> <source>&amp;Overview</source> <translation>Visã&amp;o geral</translation> </message> <message> <location line="+1"/> <source>Show general overview of wallet</source> <translation>Mostrar visão geral da carteira</translation> </message> <message> <location line="+17"/> <source>&amp;Transactions</source> <translation>&amp;Transações</translation> </message> <message> <location line="+1"/> <source>Browse transaction history</source> <translation>Navegar pelo histórico de transações</translation> </message> <message> <location line="+5"/> <source>&amp;Address Book</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Edit the list of stored addresses and labels</source> <translation type="unfinished"/> </message> <message> <location line="-13"/> <source>&amp;Receive coins</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Show the list of addresses for receiving payments</source> <translation type="unfinished"/> </message> <message> <location line="-7"/> <source>&amp;Send coins</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>E&amp;xit</source> <translation>Fec&amp;har</translation> </message> <message> <location line="+1"/> <source>Quit application</source> <translation>Sair da aplicação</translation> </message> <message> <location line="+4"/> <source>Show information about bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>About &amp;Qt</source> <translation>Sobre &amp;Qt</translation> </message> <message> <location line="+1"/> <source>Show information about Qt</source> <translation>Mostrar informação sobre Qt</translation> </message> <message> <location line="+2"/> <source>&amp;Options...</source> <translation>&amp;Opções...</translation> </message> <message> <location line="+4"/> <source>&amp;Encrypt Wallet...</source> <translation>E&amp;ncriptar Carteira...</translation> </message> <message> <location line="+3"/> <source>&amp;Backup Wallet...</source> <translation>&amp;Guardar Carteira...</translation> </message> <message> <location line="+2"/> <source>&amp;Change Passphrase...</source> <translation>Mudar &amp;Palavra-passe...</translation> </message> <message numerus="yes"> <location line="+250"/> <source>~%n block(s) remaining</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+6"/> <source>Downloaded %1 of %2 blocks of transaction history (%3% done).</source> <translation type="unfinished"/> </message> <message> <location line="-247"/> <source>&amp;Export...</source> <translation type="unfinished"/> </message> <message> <location line="-62"/> <source>Send coins to a bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+45"/> <source>Modify configuration options for bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>Export the data in the current tab to a file</source> <translation type="unfinished"/> </message> <message> <location line="-14"/> <source>Encrypt or decrypt wallet</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Backup wallet to another location</source> <translation>Faça uma cópia de segurança da carteira para outra localização</translation> </message> <message> <location line="+2"/> <source>Change the passphrase used for wallet encryption</source> <translation>Mudar a frase de segurança utilizada na encriptação da carteira</translation> </message> <message> <location line="+10"/> <source>&amp;Debug window</source> <translation>Janela de &amp;depuração</translation> </message> <message> <location line="+1"/> <source>Open debugging and diagnostic console</source> <translation>Abrir consola de diagnóstico e depuração</translation> </message> <message> <location line="-5"/> <source>&amp;Verify message...</source> <translation>&amp;Verificar mensagem...</translation> </message> <message> <location line="-200"/> <source>bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Wallet</source> <translation>Carteira</translation> </message> <message> <location line="+178"/> <source>&amp;About bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+9"/> <source>&amp;Show / Hide</source> <translation>Mo&amp;strar / Ocultar</translation> </message> <message> <location line="+9"/> <source>Unlock wallet</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>&amp;Lock Wallet</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Lock wallet</source> <translation type="unfinished"/> </message> <message> <location line="+34"/> <source>&amp;File</source> <translation>&amp;Ficheiro</translation> </message> <message> <location line="+8"/> <source>&amp;Settings</source> <translation>Con&amp;figurações</translation> </message> <message> <location line="+8"/> <source>&amp;Help</source> <translation>A&amp;juda</translation> </message> <message> <location line="+9"/> <source>Tabs toolbar</source> <translation>Barra de separadores</translation> </message> <message> <location line="+8"/> <source>Actions toolbar</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <location line="+9"/> <source>[testnet]</source> <translation>[rede de testes]</translation> </message> <message> <location line="+0"/> <location line="+60"/> <source>bitcoinlite client</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+70"/> <source>%n active connection(s) to bitcoinlite network</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+40"/> <source>Downloaded %1 blocks of transaction history.</source> <translation type="unfinished"/> </message> <message> <location line="+413"/> <source>Staking.&lt;br&gt;Your weight is %1&lt;br&gt;Network weight is %2&lt;br&gt;Expected time to earn reward is %3</source> <translation type="unfinished"/> </message> <message> <location line="+6"/> <source>Not staking because wallet is locked</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because wallet is offline</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because wallet is syncing</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because you don&apos;t have mature coins</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="-403"/> <source>%n second(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="-284"/> <source>&amp;Unlock Wallet...</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+288"/> <source>%n minute(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n hour(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n day(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+6"/> <source>Up to date</source> <translation>Atualizado</translation> </message> <message> <location line="+7"/> <source>Catching up...</source> <translation>Recuperando...</translation> </message> <message> <location line="+10"/> <source>Last received block was generated %1.</source> <translation type="unfinished"/> </message> <message> <location line="+59"/> <source>This transaction is over the size limit. You can still send it for a fee of %1, which goes to the nodes that process your transaction and helps to support the network. Do you want to pay the fee?</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Confirm transaction fee</source> <translation type="unfinished"/> </message> <message> <location line="+27"/> <source>Sent transaction</source> <translation>Transação enviada</translation> </message> <message> <location line="+1"/> <source>Incoming transaction</source> <translation>Transação recebida</translation> </message> <message> <location line="+1"/> <source>Date: %1 Amount: %2 Type: %3 Address: %4 </source> <translation>Data: %1 Quantia: %2 Tipo: %3 Endereço: %4 </translation> </message> <message> <location line="+100"/> <location line="+15"/> <source>URI handling</source> <translation type="unfinished"/> </message> <message> <location line="-15"/> <location line="+15"/> <source>URI can not be parsed! This can be caused by an invalid bitcoinlite address or malformed URI parameters.</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;unlocked&lt;/b&gt;</source> <translation>A carteira está &lt;b&gt;encriptada&lt;/b&gt; e atualmente &lt;b&gt;desbloqueada&lt;/b&gt;</translation> </message> <message> <location line="+10"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;locked&lt;/b&gt;</source> <translation>A carteira está &lt;b&gt;encriptada&lt;/b&gt; e atualmente &lt;b&gt;bloqueada&lt;/b&gt;</translation> </message> <message> <location line="+25"/> <source>Backup Wallet</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Wallet Data (*.dat)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Backup Failed</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>There was an error trying to save the wallet data to the new location.</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+76"/> <source>%n second(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n minute(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n hour(s)</source> <translation><numerusform>%n hora</numerusform><numerusform>%n horas</numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n day(s)</source> <translation><numerusform>%n dia</numerusform><numerusform>%n dias</numerusform></translation> </message> <message> <location line="+18"/> <source>Not staking</source> <translation type="unfinished"/> </message> <message> <location filename="../bitcoin.cpp" line="+109"/> <source>A fatal error occurred. bitcoinlite can no longer continue safely and will quit.</source> <translation type="unfinished"/> </message> </context> <context> <name>ClientModel</name> <message> <location filename="../clientmodel.cpp" line="+90"/> <source>Network Alert</source> <translation>Alerta da Rede</translation> </message> </context> <context> <name>CoinControlDialog</name> <message> <location filename="../forms/coincontroldialog.ui" line="+14"/> <source>Coin Control</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Quantity:</source> <translation>Quantidade:</translation> </message> <message> <location line="+32"/> <source>Bytes:</source> <translation>Bytes:</translation> </message> <message> <location line="+48"/> <source>Amount:</source> <translation>Quantia:</translation> </message> <message> <location line="+32"/> <source>Priority:</source> <translation>Prioridade:</translation> </message> <message> <location line="+48"/> <source>Fee:</source> <translation>Taxa:</translation> </message> <message> <location line="+35"/> <source>Low Output:</source> <translation>Saída Baixa:</translation> </message> <message> <location filename="../coincontroldialog.cpp" line="+551"/> <source>no</source> <translation>não</translation> </message> <message> <location filename="../forms/coincontroldialog.ui" line="+51"/> <source>After Fee:</source> <translation>Depois de taxas:</translation> </message> <message> <location line="+35"/> <source>Change:</source> <translation>Troco:</translation> </message> <message> <location line="+69"/> <source>(un)select all</source> <translation>(des)seleccionar todos</translation> </message> <message> <location line="+13"/> <source>Tree mode</source> <translation>Modo de árvore</translation> </message> <message> <location line="+16"/> <source>List mode</source> <translation>Modo lista</translation> </message> <message> <location line="+45"/> <source>Amount</source> <translation>Quantia</translation> </message> <message> <location line="+5"/> <source>Label</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Address</source> <translation>Endereço</translation> </message> <message> <location line="+5"/> <source>Date</source> <translation>Data</translation> </message> <message> <location line="+5"/> <source>Confirmations</source> <translation>Confirmados</translation> </message> <message> <location line="+3"/> <source>Confirmed</source> <translation>Confirmada</translation> </message> <message> <location line="+5"/> <source>Priority</source> <translation>Prioridade</translation> </message> <message> <location filename="../coincontroldialog.cpp" line="-515"/> <source>Copy address</source> <translation>Copiar endereço</translation> </message> <message> <location line="+1"/> <source>Copy label</source> <translation>Copiar rótulo</translation> </message> <message> <location line="+1"/> <location line="+26"/> <source>Copy amount</source> <translation>Copiar quantia</translation> </message> <message> <location line="-25"/> <source>Copy transaction ID</source> <translation>Copiar ID da Transação</translation> </message> <message> <location line="+24"/> <source>Copy quantity</source> <translation>Copiar quantidade</translation> </message> <message> <location line="+2"/> <source>Copy fee</source> <translation>Taxa de cópia</translation> </message> <message> <location line="+1"/> <source>Copy after fee</source> <translation>Taxa depois de cópia</translation> </message> <message> <location line="+1"/> <source>Copy bytes</source> <translation>Copiar bytes</translation> </message> <message> <location line="+1"/> <source>Copy priority</source> <translation>Prioridade de Cópia</translation> </message> <message> <location line="+1"/> <source>Copy low output</source> <translation>Copiar output baixo</translation> </message> <message> <location line="+1"/> <source>Copy change</source> <translation>Copiar alteração</translation> </message> <message> <location line="+317"/> <source>highest</source> <translation>o maior</translation> </message> <message> <location line="+1"/> <source>high</source> <translation>alto</translation> </message> <message> <location line="+1"/> <source>medium-high</source> <translation>médio-alto</translation> </message> <message> <location line="+1"/> <source>medium</source> <translation>médio</translation> </message> <message> <location line="+4"/> <source>low-medium</source> <translation>baixo-médio</translation> </message> <message> <location line="+1"/> <source>low</source> <translation>baixo</translation> </message> <message> <location line="+1"/> <source>lowest</source> <translation>O mais baixo</translation> </message> <message> <location line="+155"/> <source>DUST</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>yes</source> <translation>sim</translation> </message> <message> <location line="+10"/> <source>This label turns red, if the transaction size is bigger than 10000 bytes. This means a fee of at least %1 per kb is required. Can vary +/- 1 Byte per input.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Transactions with higher priority get more likely into a block. This label turns red, if the priority is smaller than &quot;medium&quot;. This means a fee of at least %1 per kb is required.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>This label turns red, if any recipient receives an amount smaller than %1. This means a fee of at least %2 is required. Amounts below 0.546 times the minimum relay fee are shown as DUST.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>This label turns red, if the change is smaller than %1. This means a fee of at least %2 is required.</source> <translation type="unfinished"/> </message> <message> <location line="+37"/> <location line="+66"/> <source>(no label)</source> <translation>(Sem rótulo)</translation> </message> <message> <location line="-9"/> <source>change from %1 (%2)</source> <translation>Alteração de %1 (%2)</translation> </message> <message> <location line="+1"/> <source>(change)</source> <translation>(Alteração)</translation> </message> </context> <context> <name>EditAddressDialog</name> <message> <location filename="../forms/editaddressdialog.ui" line="+14"/> <source>Edit Address</source> <translation>Editar Endereço</translation> </message> <message> <location line="+11"/> <source>&amp;Label</source> <translation>&amp;Rótulo</translation> </message> <message> <location line="+10"/> <source>The label associated with this address book entry</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>&amp;Address</source> <translation>E&amp;ndereço</translation> </message> <message> <location line="+10"/> <source>The address associated with this address book entry. This can only be modified for sending addresses.</source> <translation type="unfinished"/> </message> <message> <location filename="../editaddressdialog.cpp" line="+20"/> <source>New receiving address</source> <translation>Novo endereço de entrada</translation> </message> <message> <location line="+4"/> <source>New sending address</source> <translation>Novo endereço de saída</translation> </message> <message> <location line="+3"/> <source>Edit receiving address</source> <translation>Editar endereço de entrada</translation> </message> <message> <location line="+4"/> <source>Edit sending address</source> <translation>Editar endereço de saída</translation> </message> <message> <location line="+76"/> <source>The entered address &quot;%1&quot; is already in the address book.</source> <translation>O endereço introduzido &quot;%1&quot; já se encontra no livro de endereços.</translation> </message> <message> <location line="-5"/> <source>The entered address &quot;%1&quot; is not a valid bitcoinlite address.</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Could not unlock wallet.</source> <translation>Impossível desbloquear carteira.</translation> </message> <message> <location line="+5"/> <source>New key generation failed.</source> <translation>Falha ao gerar nova chave.</translation> </message> </context> <context> <name>GUIUtil::HelpMessageBox</name> <message> <location filename="../guiutil.cpp" line="+420"/> <location line="+12"/> <source>bitcoinlite-Qt</source> <translation type="unfinished"/> </message> <message> <location line="-12"/> <source>version</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Usage:</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>command-line options</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>UI options</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Set language, for example &quot;de_DE&quot; (default: system locale)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Start minimized</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Show splash screen on startup (default: 1)</source> <translation type="unfinished"/> </message> </context> <context> <name>OptionsDialog</name> <message> <location filename="../forms/optionsdialog.ui" line="+14"/> <source>Options</source> <translation>Opções</translation> </message> <message> <location line="+16"/> <source>&amp;Main</source> <translation>&amp;Principal</translation> </message> <message> <location line="+6"/> <source>Optional transaction fee per kB that helps make sure your transactions are processed quickly. Most transactions are 1 kB. Fee 0.01 recommended.</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Pay transaction &amp;fee</source> <translation>Pagar &amp;taxa de transação</translation> </message> <message> <location line="+31"/> <source>Reserved amount does not participate in staking and is therefore spendable at any time.</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Reserve</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Automatically start bitcoinlite after logging in to the system.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Start bitcoinlite on system login</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Detach block and address databases at shutdown. This means they can be moved to another data directory, but it slows down shutdown. The wallet is always detached.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Detach databases at shutdown</source> <translation type="unfinished"/> </message> <message> <location line="+21"/> <source>&amp;Network</source> <translation>&amp;Rede</translation> </message> <message> <location line="+6"/> <source>Automatically open the bitcoinlite client port on the router. This only works when your router supports UPnP and it is enabled.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Map port using &amp;UPnP</source> <translation>Mapear porta usando &amp;UPnP</translation> </message> <message> <location line="+7"/> <source>Connect to the bitcoinlite network through a SOCKS proxy (e.g. when connecting through Tor).</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Connect through SOCKS proxy:</source> <translation type="unfinished"/> </message> <message> <location line="+9"/> <source>Proxy &amp;IP:</source> <translation>&amp;IP do proxy:</translation> </message> <message> <location line="+19"/> <source>IP address of the proxy (e.g. 127.0.0.1)</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>&amp;Port:</source> <translation>&amp;Porta:</translation> </message> <message> <location line="+19"/> <source>Port of the proxy (e.g. 9050)</source> <translation>Porta do proxy (p.ex. 9050)</translation> </message> <message> <location line="+7"/> <source>SOCKS &amp;Version:</source> <translation>&amp;Versão SOCKS:</translation> </message> <message> <location line="+13"/> <source>SOCKS version of the proxy (e.g. 5)</source> <translation>Versão do proxy SOCKS (p.ex. 5)</translation> </message> <message> <location line="+36"/> <source>&amp;Window</source> <translation>&amp;Janela</translation> </message> <message> <location line="+6"/> <source>Show only a tray icon after minimizing the window.</source> <translation>Apenas mostrar o ícone da bandeja após minimizar a janela.</translation> </message> <message> <location line="+3"/> <source>&amp;Minimize to the tray instead of the taskbar</source> <translation>&amp;Minimizar para a bandeja e não para a barra de ferramentas</translation> </message> <message> <location line="+7"/> <source>Minimize instead of exit the application when the window is closed. When this option is enabled, the application will be closed only after selecting Quit in the menu.</source> <translation>Minimize ao invés de sair da aplicação quando a janela é fechada. Com esta opção selecionada, a aplicação apenas será encerrada quando escolher Sair da aplicação no menú.</translation> </message> <message> <location line="+3"/> <source>M&amp;inimize on close</source> <translation>M&amp;inimizar ao fechar</translation> </message> <message> <location line="+21"/> <source>&amp;Display</source> <translation>Vis&amp;ualização</translation> </message> <message> <location line="+8"/> <source>User Interface &amp;language:</source> <translation>&amp;Linguagem da interface de utilizador:</translation> </message> <message> <location line="+13"/> <source>The user interface language can be set here. This setting will take effect after restarting bitcoinlite.</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>&amp;Unit to show amounts in:</source> <translation>&amp;Unidade a usar em quantias:</translation> </message> <message> <location line="+13"/> <source>Choose the default subdivision unit to show in the interface and when sending coins.</source> <translation>Escolha a subdivisão unitária a ser mostrada por defeito na aplicação e ao enviar moedas.</translation> </message> <message> <location line="+9"/> <source>Whether to show bitcoinlite addresses in the transaction list or not.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Display addresses in transaction list</source> <translation>Mostrar en&amp;dereços na lista de transações</translation> </message> <message> <location line="+7"/> <source>Whether to show coin control features or not.</source> <translation>Escolha para mostrar funcionalidades de controlo &quot;coin&quot; ou não.</translation> </message> <message> <location line="+3"/> <source>Display coin &amp;control features (experts only!)</source> <translation type="unfinished"/> </message> <message> <location line="+71"/> <source>&amp;OK</source> <translation>&amp;OK</translation> </message> <message> <location line="+7"/> <source>&amp;Cancel</source> <translation>&amp;Cancelar</translation> </message> <message> <location line="+10"/> <source>&amp;Apply</source> <translation type="unfinished"/> </message> <message> <location filename="../optionsdialog.cpp" line="+55"/> <source>default</source> <translation>padrão</translation> </message> <message> <location line="+149"/> <location line="+9"/> <source>Warning</source> <translation type="unfinished"/> </message> <message> <location line="-9"/> <location line="+9"/> <source>This setting will take effect after restarting bitcoinlite.</source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>The supplied proxy address is invalid.</source> <translation>O endereço de proxy introduzido é inválido. </translation> </message> </context> <context> <name>OverviewPage</name> <message> <location filename="../forms/overviewpage.ui" line="+14"/> <source>Form</source> <translation>Formulário</translation> </message> <message> <location line="+33"/> <location line="+231"/> <source>The displayed information may be out of date. Your wallet automatically synchronizes with the bitcoinlite network after a connection is established, but this process has not completed yet.</source> <translation type="unfinished"/> </message> <message> <location line="-160"/> <source>Stake:</source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>Unconfirmed:</source> <translation type="unfinished"/> </message> <message> <location line="-107"/> <source>Wallet</source> <translation>Carteira</translation> </message> <message> <location line="+49"/> <source>Spendable:</source> <translation type="unfinished"/> </message> <message> <location line="+16"/> <source>Your current spendable balance</source> <translation>O seu saldo disponível para gastar</translation> </message> <message> <location line="+71"/> <source>Immature:</source> <translation>Imaturo:</translation> </message> <message> <location line="+13"/> <source>Mined balance that has not yet matured</source> <translation>O saldo minado ainda não maturou</translation> </message> <message> <location line="+20"/> <source>Total:</source> <translation>Total:</translation> </message> <message> <location line="+16"/> <source>Your current total balance</source> <translation>O seu saldo total actual</translation> </message> <message> <location line="+46"/> <source>&lt;b&gt;Recent transactions&lt;/b&gt;</source> <translation>&lt;b&gt;Transações recentes&lt;/b&gt;</translation> </message> <message> <location line="-108"/> <source>Total of transactions that have yet to be confirmed, and do not yet count toward the current balance</source> <translation type="unfinished"/> </message> <message> <location line="-29"/> <source>Total of coins that was staked, and do not yet count toward the current balance</source> <translation type="unfinished"/> </message> <message> <location filename="../overviewpage.cpp" line="+113"/> <location line="+1"/> <source>out of sync</source> <translation>fora de sincronia</translation> </message> </context> <context> <name>QRCodeDialog</name> <message> <location filename="../forms/qrcodedialog.ui" line="+14"/> <source>QR Code Dialog</source> <translation type="unfinished"/> </message> <message> <location line="+59"/> <source>Request Payment</source> <translation type="unfinished"/> </message> <message> <location line="+56"/> <source>Amount:</source> <translation type="unfinished"/> </message> <message> <location line="-44"/> <source>Label:</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>Message:</source> <translation type="unfinished"/> </message> <message> <location line="+71"/> <source>&amp;Save As...</source> <translation type="unfinished"/> </message> <message> <location filename="../qrcodedialog.cpp" line="+62"/> <source>Error encoding URI into QR Code.</source> <translation type="unfinished"/> </message> <message> <location line="+40"/> <source>The entered amount is invalid, please check.</source> <translation type="unfinished"/> </message> <message> <location line="+23"/> <source>Resulting URI too long, try to reduce the text for label / message.</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Save QR Code</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>PNG Images (*.png)</source> <translation type="unfinished"/> </message> </context> <context> <name>RPCConsole</name> <message> <location filename="../forms/rpcconsole.ui" line="+46"/> <source>Client name</source> <translation>Nome do Cliente</translation> </message> <message> <location line="+10"/> <location line="+23"/> <location line="+26"/> <location line="+23"/> <location line="+23"/> <location line="+36"/> <location line="+53"/> <location line="+23"/> <location line="+23"/> <location filename="../rpcconsole.cpp" line="+348"/> <source>N/A</source> <translation>N/D</translation> </message> <message> <location line="-217"/> <source>Client version</source> <translation>Versão do Cliente</translation> </message> <message> <location line="-45"/> <source>&amp;Information</source> <translation>&amp;Informação</translation> </message> <message> <location line="+68"/> <source>Using OpenSSL version</source> <translation>Usando versão OpenSSL</translation> </message> <message> <location line="+49"/> <source>Startup time</source> <translation>Tempo de início</translation> </message> <message> <location line="+29"/> <source>Network</source> <translation>Rede</translation> </message> <message> <location line="+7"/> <source>Number of connections</source> <translation>Número de ligações</translation> </message> <message> <location line="+23"/> <source>On testnet</source> <translation type="unfinished"/> </message> <message> <location line="+23"/> <source>Block chain</source> <translation>Cadeia de blocos</translation> </message> <message> <location line="+7"/> <source>Current number of blocks</source> <translation>Número actual de blocos</translation> </message> <message> <location line="+23"/> <source>Estimated total blocks</source> <translation>Total estimado de blocos</translation> </message> <message> <location line="+23"/> <source>Last block time</source> <translation>Tempo do último bloco</translation> </message> <message> <location line="+52"/> <source>&amp;Open</source> <translation>&amp;Abrir</translation> </message> <message> <location line="+16"/> <source>Command-line options</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Show the bitcoinlite-Qt help message to get a list with possible bitcoinlite command-line options.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Show</source> <translation type="unfinished"/> </message> <message> <location line="+24"/> <source>&amp;Console</source> <translation>&amp;Consola</translation> </message> <message> <location line="-260"/> <source>Build date</source> <translation>Data de construção</translation> </message> <message> <location line="-104"/> <source>bitcoinlite - Debug window</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>bitcoinlite Core</source> <translation type="unfinished"/> </message> <message> <location line="+279"/> <source>Debug log file</source> <translation>Ficheiro de registo de depuração</translation> </message> <message> <location line="+7"/> <source>Open the bitcoinlite debug log file from the current data directory. This can take a few seconds for large log files.</source> <translation type="unfinished"/> </message> <message> <location line="+102"/> <source>Clear console</source> <translation>Limpar consola</translation> </message> <message> <location filename="../rpcconsole.cpp" line="-33"/> <source>Welcome to the bitcoinlite RPC console.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Use up and down arrows to navigate history, and &lt;b&gt;Ctrl-L&lt;/b&gt; to clear screen.</source> <translation>Use as setas para cima e para baixo para navegar no histórico e &lt;b&gt;Ctrl-L&lt;/b&gt; para limpar o ecrã.</translation> </message> <message> <location line="+1"/> <source>Type &lt;b&gt;help&lt;/b&gt; for an overview of available commands.</source> <translation>Digite &lt;b&gt;help&lt;/b&gt; para visualizar os comandos disponíveis.</translation> </message> </context> <context> <name>SendCoinsDialog</name> <message> <location filename="../forms/sendcoinsdialog.ui" line="+14"/> <location filename="../sendcoinsdialog.cpp" line="+182"/> <location line="+5"/> <location line="+5"/> <location line="+5"/> <location line="+6"/> <location line="+5"/> <location line="+5"/> <source>Send Coins</source> <translation>Enviar Moedas</translation> </message> <message> <location line="+76"/> <source>Coin Control Features</source> <translation>Funcionalidades de Coin Controlo:</translation> </message> <message> <location line="+20"/> <source>Inputs...</source> <translation>Entradas</translation> </message> <message> <location line="+7"/> <source>automatically selected</source> <translation>Selecção automática</translation> </message> <message> <location line="+19"/> <source>Insufficient funds!</source> <translation>Fundos insuficientes!</translation> </message> <message> <location line="+77"/> <source>Quantity:</source> <translation>Quantidade:</translation> </message> <message> <location line="+22"/> <location line="+35"/> <source>0</source> <translation type="unfinished"/> </message> <message> <location line="-19"/> <source>Bytes:</source> <translation>Bytes:</translation> </message> <message> <location line="+51"/> <source>Amount:</source> <translation>Quantia:</translation> </message> <message> <location line="+22"/> <location line="+86"/> <location line="+86"/> <location line="+32"/> <source>0.00 BC</source> <translation type="unfinished"/> </message> <message> <location line="-191"/> <source>Priority:</source> <translation>Prioridade:</translation> </message> <message> <location line="+19"/> <source>medium</source> <translation type="unfinished"/> </message> <message> <location line="+32"/> <source>Fee:</source> <translation>Taxa:</translation> </message> <message> <location line="+35"/> <source>Low Output:</source> <translation>Output Baixo:</translation> </message> <message> <location line="+19"/> <source>no</source> <translation type="unfinished"/> </message> <message> <location line="+32"/> <source>After Fee:</source> <translation>Depois de taxas:</translation> </message> <message> <location line="+35"/> <source>Change</source> <translation type="unfinished"/> </message> <message> <location line="+50"/> <source>custom change address</source> <translation type="unfinished"/> </message> <message> <location line="+106"/> <source>Send to multiple recipients at once</source> <translation>Enviar para múltiplos destinatários de uma vez</translation> </message> <message> <location line="+3"/> <source>Add &amp;Recipient</source> <translation>Adicionar &amp;Destinatário</translation> </message> <message> <location line="+20"/> <source>Remove all transaction fields</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Clear &amp;All</source> <translation>&amp;Limpar Tudo</translation> </message> <message> <location line="+28"/> <source>Balance:</source> <translation>Saldo:</translation> </message> <message> <location line="+16"/> <source>123.456 BC</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Confirm the send action</source> <translation>Confirme ação de envio</translation> </message> <message> <location line="+3"/> <source>S&amp;end</source> <translation>&amp;Enviar</translation> </message> <message> <location filename="../sendcoinsdialog.cpp" line="-173"/> <source>Enter a bitcoinlite address (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Copy quantity</source> <translation>Copiar quantidade</translation> </message> <message> <location line="+1"/> <source>Copy amount</source> <translation>Copiar quantia</translation> </message> <message> <location line="+1"/> <source>Copy fee</source> <translation>Taxa de cópia</translation> </message> <message> <location line="+1"/> <source>Copy after fee</source> <translation>Taxa depois de cópia</translation> </message> <message> <location line="+1"/> <source>Copy bytes</source> <translation>Copiar bytes</translation> </message> <message> <location line="+1"/> <source>Copy priority</source> <translation>Prioridade de Cópia</translation> </message> <message> <location line="+1"/> <source>Copy low output</source> <translation>Copiar output baixo</translation> </message> <message> <location line="+1"/> <source>Copy change</source> <translation>Copiar alteração</translation> </message> <message> <location line="+86"/> <source>&lt;b&gt;%1&lt;/b&gt; to %2 (%3)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Confirm send coins</source> <translation>Confirme envio de moedas</translation> </message> <message> <location line="+1"/> <source>Are you sure you want to send %1?</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source> and </source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>The recipient address is not valid, please recheck.</source> <translation>O endereço de destino não é válido, por favor verifique.</translation> </message> <message> <location line="+5"/> <source>The amount to pay must be larger than 0.</source> <translation>A quantia a pagar deverá ser maior que 0.</translation> </message> <message> <location line="+5"/> <source>The amount exceeds your balance.</source> <translation>A quantia excede o seu saldo.</translation> </message> <message> <location line="+5"/> <source>The total exceeds your balance when the %1 transaction fee is included.</source> <translation>O total excede o seu saldo quando a taxa de transação de %1 for incluída.</translation> </message> <message> <location line="+6"/> <source>Duplicate address found, can only send to each address once per send operation.</source> <translation>Endereço duplicado encontrado, apenas poderá enviar uma vez para cada endereço por cada operação de envio.</translation> </message> <message> <location line="+5"/> <source>Error: Transaction creation failed.</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Error: The transaction was rejected. This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation type="unfinished"/> </message> <message> <location line="+251"/> <source>WARNING: Invalid bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>(no label)</source> <translation>(Sem rótulo)</translation> </message> <message> <location line="+4"/> <source>WARNING: unknown change address</source> <translation type="unfinished"/> </message> </context> <context> <name>SendCoinsEntry</name> <message> <location filename="../forms/sendcoinsentry.ui" line="+14"/> <source>Form</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>A&amp;mount:</source> <translation>Qu&amp;antia:</translation> </message> <message> <location line="+13"/> <source>Pay &amp;To:</source> <translation>&amp;Pagar A:</translation> </message> <message> <location line="+24"/> <location filename="../sendcoinsentry.cpp" line="+25"/> <source>Enter a label for this address to add it to your address book</source> <translation>Escreva um rótulo para este endereço para o adicionar ao seu livro de endereços</translation> </message> <message> <location line="+9"/> <source>&amp;Label:</source> <translation>Rótu&amp;lo:</translation> </message> <message> <location line="+18"/> <source>The address to send the payment to (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Choose address from address book</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="+7"/> <source>Paste address from clipboard</source> <translation>Cole endereço da área de transferência</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+7"/> <source>Remove this recipient</source> <translation type="unfinished"/> </message> <message> <location filename="../sendcoinsentry.cpp" line="+1"/> <source>Enter a bitcoinlite address (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> </context> <context> <name>SignVerifyMessageDialog</name> <message> <location filename="../forms/signverifymessagedialog.ui" line="+14"/> <source>Signatures - Sign / Verify a Message</source> <translation>Assinaturas - Assinar / Verificar uma Mensagem</translation> </message> <message> <location line="+13"/> <location line="+124"/> <source>&amp;Sign Message</source> <translation>A&amp;ssinar Mensagem</translation> </message> <message> <location line="-118"/> <source>You can sign messages with your addresses to prove you own them. Be careful not to sign anything vague, as phishing attacks may try to trick you into signing your identity over to them. Only sign fully-detailed statements you agree to.</source> <translation>Pode assinar mensagens com os seus endereços para provar que são seus. Tenha atenção ao assinar mensagens ambíguas, pois ataques de phishing podem tentar enganá-lo, de modo a assinar a sua identidade para os atacantes. Apenas assine declarações completamente detalhadas com as quais concorde.</translation> </message> <message> <location line="+18"/> <source>The address to sign the message with (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <location line="+203"/> <source>Choose an address from the address book</source> <translation type="unfinished"/> </message> <message> <location line="-193"/> <location line="+203"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="-193"/> <source>Paste address from clipboard</source> <translation>Cole endereço da área de transferência</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+12"/> <source>Enter the message you want to sign here</source> <translation>Escreva aqui a mensagem que deseja assinar</translation> </message> <message> <location line="+24"/> <source>Copy the current signature to the system clipboard</source> <translation>Copiar a assinatura actual para a área de transferência</translation> </message> <message> <location line="+21"/> <source>Sign the message to prove you own this bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+17"/> <source>Reset all sign message fields</source> <translation>Repôr todos os campos de assinatura de mensagem</translation> </message> <message> <location line="+3"/> <location line="+146"/> <source>Clear &amp;All</source> <translation>Limpar &amp;Tudo</translation> </message> <message> <location line="-87"/> <location line="+70"/> <source>&amp;Verify Message</source> <translation>&amp;Verificar Mensagem</translation> </message> <message> <location line="-64"/> <source>Enter the signing address, message (ensure you copy line breaks, spaces, tabs, etc. exactly) and signature below to verify the message. Be careful not to read more into the signature than what is in the signed message itself, to avoid being tricked by a man-in-the-middle attack.</source> <translation>Introduza o endereço de assinatura, mensagem (assegure-se de copiar quebras de linha, espaços, tabuladores, etc. exactamente) e assinatura abaixo para verificar a mensagem. Tenha atenção para não ler mais na assinatura do que o que estiver na mensagem assinada, para evitar ser enganado por um atacante que se encontre entre si e quem assinou a mensagem.</translation> </message> <message> <location line="+21"/> <source>The address the message was signed with (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> <message> <location line="+40"/> <source>Verify the message to ensure it was signed with the specified bitcoinlite address</source> <translation type="unfinished"/> </message> <message> <location line="+17"/> <source>Reset all verify message fields</source> <translation>Repôr todos os campos de verificação de mensagem</translation> </message> <message> <location filename="../signverifymessagedialog.cpp" line="+27"/> <location line="+3"/> <source>Enter a bitcoinlite address (e.g. RJhbfkAFvXqYkreSgJfrRLS9DepUcxbQci)</source> <translation type="unfinished"/> </message> <message> <location line="-2"/> <source>Click &quot;Sign Message&quot; to generate signature</source> <translation>Clique &quot;Assinar mensagem&quot; para gerar a assinatura</translation> </message> <message> <location line="+3"/> <source>Enter bitcoinlite signature</source> <translation type="unfinished"/> </message> <message> <location line="+82"/> <location line="+81"/> <source>The entered address is invalid.</source> <translation>O endereço introduzido é inválido. </translation> </message> <message> <location line="-81"/> <location line="+8"/> <location line="+73"/> <location line="+8"/> <source>Please check the address and try again.</source> <translation>Por favor verifique o endereço e tente de novo.</translation> </message> <message> <location line="-81"/> <location line="+81"/> <source>The entered address does not refer to a key.</source> <translation>O endereço introduzido não refere a chave alguma.</translation> </message> <message> <location line="-73"/> <source>Wallet unlock was cancelled.</source> <translation>O desbloqueio da carteira foi cancelado.</translation> </message> <message> <location line="+8"/> <source>Private key for the entered address is not available.</source> <translation>A chave privada para o endereço introduzido não está disponível.</translation> </message> <message> <location line="+12"/> <source>Message signing failed.</source> <translation>Assinatura de mensagem falhou.</translation> </message> <message> <location line="+5"/> <source>Message signed.</source> <translation>Mensagem assinada.</translation> </message> <message> <location line="+59"/> <source>The signature could not be decoded.</source> <translation>A assinatura não pôde ser descodificada.</translation> </message> <message> <location line="+0"/> <location line="+13"/> <source>Please check the signature and try again.</source> <translation>Por favor verifique a assinatura e tente de novo.</translation> </message> <message> <location line="+0"/> <source>The signature did not match the message digest.</source> <translation>A assinatura não condiz com o conteúdo da mensagem.</translation> </message> <message> <location line="+7"/> <source>Message verification failed.</source> <translation>Verificação da mensagem falhou.</translation> </message> <message> <location line="+5"/> <source>Message verified.</source> <translation>Mensagem verificada.</translation> </message> </context> <context> <name>TransactionDesc</name> <message> <location filename="../transactiondesc.cpp" line="+19"/> <source>Open until %1</source> <translation>Aberto até %1</translation> </message> <message numerus="yes"> <location line="-2"/> <source>Open for %n block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+8"/> <source>conflicted</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>%1/offline</source> <translation>%1/desligado</translation> </message> <message> <location line="+2"/> <source>%1/unconfirmed</source> <translation>%1/não confirmada</translation> </message> <message> <location line="+2"/> <source>%1 confirmations</source> <translation>%1 confirmações</translation> </message> <message> <location line="+18"/> <source>Status</source> <translation>Estado</translation> </message> <message numerus="yes"> <location line="+7"/> <source>, broadcast through %n node(s)</source> <translation><numerusform>, transmitida através de %n nó</numerusform><numerusform>, transmitida através de %n nós</numerusform></translation> </message> <message> <location line="+4"/> <source>Date</source> <translation>Data</translation> </message> <message> <location line="+7"/> <source>Source</source> <translation>Origem</translation> </message> <message> <location line="+0"/> <source>Generated</source> <translation>Gerado</translation> </message> <message> <location line="+5"/> <location line="+17"/> <source>From</source> <translation>De</translation> </message> <message> <location line="+1"/> <location line="+22"/> <location line="+58"/> <source>To</source> <translation>Para</translation> </message> <message> <location line="-77"/> <location line="+2"/> <source>own address</source> <translation>endereço próprio</translation> </message> <message> <location line="-2"/> <source>label</source> <translation>rótulo</translation> </message> <message> <location line="+37"/> <location line="+12"/> <location line="+45"/> <location line="+17"/> <location line="+30"/> <source>Credit</source> <translation>Crédito</translation> </message> <message numerus="yes"> <location line="-102"/> <source>matures in %n more block(s)</source> <translation><numerusform>matura daqui por %n bloco</numerusform><numerusform>matura daqui por %n blocos</numerusform></translation> </message> <message> <location line="+2"/> <source>not accepted</source> <translation>não aceite</translation> </message> <message> <location line="+44"/> <location line="+8"/> <location line="+15"/> <location line="+30"/> <source>Debit</source> <translation>Débito</translation> </message> <message> <location line="-39"/> <source>Transaction fee</source> <translation>Taxa de transação</translation> </message> <message> <location line="+16"/> <source>Net amount</source> <translation>Valor líquido</translation> </message> <message> <location line="+6"/> <source>Message</source> <translation>Mensagem</translation> </message> <message> <location line="+2"/> <source>Comment</source> <translation>Comentário</translation> </message> <message> <location line="+2"/> <source>Transaction ID</source> <translation>ID da Transação</translation> </message> <message> <location line="+3"/> <source>Generated coins must mature 110 blocks before they can be spent. When you generated this block, it was broadcast to the network to be added to the block chain. If it fails to get into the chain, its state will change to &quot;not accepted&quot; and it won&apos;t be spendable. This may occasionally happen if another node generates a block within a few seconds of yours.</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Debug information</source> <translation>Informação de depuração</translation> </message> <message> <location line="+8"/> <source>Transaction</source> <translation>Transação</translation> </message> <message> <location line="+5"/> <source>Inputs</source> <translation>Entradas</translation> </message> <message> <location line="+23"/> <source>Amount</source> <translation>Quantia</translation> </message> <message> <location line="+1"/> <source>true</source> <translation>verdadeiro</translation> </message> <message> <location line="+0"/> <source>false</source> <translation>falso</translation> </message> <message> <location line="-211"/> <source>, has not been successfully broadcast yet</source> <translation>, ainda não foi transmitida com sucesso</translation> </message> <message> <location line="+35"/> <source>unknown</source> <translation>desconhecido</translation> </message> </context> <context> <name>TransactionDescDialog</name> <message> <location filename="../forms/transactiondescdialog.ui" line="+14"/> <source>Transaction details</source> <translation>Detalhes da transação</translation> </message> <message> <location line="+6"/> <source>This pane shows a detailed description of the transaction</source> <translation>Esta janela mostra uma descrição detalhada da transação</translation> </message> </context> <context> <name>TransactionTableModel</name> <message> <location filename="../transactiontablemodel.cpp" line="+226"/> <source>Date</source> <translation>Data</translation> </message> <message> <location line="+0"/> <source>Type</source> <translation>Tipo</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Endereço</translation> </message> <message> <location line="+0"/> <source>Amount</source> <translation>Quantia</translation> </message> <message> <location line="+60"/> <source>Open until %1</source> <translation>Aberto até %1</translation> </message> <message> <location line="+12"/> <source>Confirmed (%1 confirmations)</source> <translation>Confirmada (%1 confirmações)</translation> </message> <message numerus="yes"> <location line="-15"/> <source>Open for %n more block(s)</source> <translation><numerusform>Aberta por mais %n bloco</numerusform><numerusform>Aberta por mais %n blocos</numerusform></translation> </message> <message> <location line="+6"/> <source>Offline</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Unconfirmed</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Confirming (%1 of %2 recommended confirmations)</source> <translation type="unfinished"/> </message><|fim▁hole|> <source>Conflicted</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Immature (%1 confirmations, will be available after %2)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>This block was not received by any other nodes and will probably not be accepted!</source> <translation>Este bloco não foi recebido por outros nós e provavelmente não será aceite pela rede!</translation> </message> <message> <location line="+3"/> <source>Generated but not accepted</source> <translation>Gerado mas não aceite</translation> </message> <message> <location line="+42"/> <source>Received with</source> <translation>Recebido com</translation> </message> <message> <location line="+2"/> <source>Received from</source> <translation>Recebido de</translation> </message> <message> <location line="+3"/> <source>Sent to</source> <translation>Enviado para</translation> </message> <message> <location line="+2"/> <source>Payment to yourself</source> <translation>Pagamento ao próprio</translation> </message> <message> <location line="+2"/> <source>Mined</source> <translation>Minadas</translation> </message> <message> <location line="+38"/> <source>(n/a)</source> <translation>(n/d)</translation> </message> <message> <location line="+190"/> <source>Transaction status. Hover over this field to show number of confirmations.</source> <translation>Estado da transação. Pairar por cima deste campo para mostrar o número de confirmações.</translation> </message> <message> <location line="+2"/> <source>Date and time that the transaction was received.</source> <translation>Data e hora a que esta transação foi recebida.</translation> </message> <message> <location line="+2"/> <source>Type of transaction.</source> <translation>Tipo de transação.</translation> </message> <message> <location line="+2"/> <source>Destination address of transaction.</source> <translation>Endereço de destino da transação.</translation> </message> <message> <location line="+2"/> <source>Amount removed from or added to balance.</source> <translation>Quantia retirada ou adicionada ao saldo.</translation> </message> </context> <context> <name>TransactionView</name> <message> <location filename="../transactionview.cpp" line="+55"/> <location line="+16"/> <source>All</source> <translation>Todas</translation> </message> <message> <location line="-15"/> <source>Today</source> <translation>Hoje</translation> </message> <message> <location line="+1"/> <source>This week</source> <translation>Esta semana</translation> </message> <message> <location line="+1"/> <source>This month</source> <translation>Este mês</translation> </message> <message> <location line="+1"/> <source>Last month</source> <translation>Mês passado</translation> </message> <message> <location line="+1"/> <source>This year</source> <translation>Este ano</translation> </message> <message> <location line="+1"/> <source>Range...</source> <translation>Período...</translation> </message> <message> <location line="+11"/> <source>Received with</source> <translation>Recebida com</translation> </message> <message> <location line="+2"/> <source>Sent to</source> <translation>Enviada para</translation> </message> <message> <location line="+2"/> <source>To yourself</source> <translation>Para si</translation> </message> <message> <location line="+1"/> <source>Mined</source> <translation>Minadas</translation> </message> <message> <location line="+1"/> <source>Other</source> <translation>Outras</translation> </message> <message> <location line="+7"/> <source>Enter address or label to search</source> <translation>Escreva endereço ou rótulo a procurar</translation> </message> <message> <location line="+7"/> <source>Min amount</source> <translation>Quantia mínima</translation> </message> <message> <location line="+34"/> <source>Copy address</source> <translation>Copiar endereço</translation> </message> <message> <location line="+1"/> <source>Copy label</source> <translation>Copiar rótulo</translation> </message> <message> <location line="+1"/> <source>Copy amount</source> <translation>Copiar quantia</translation> </message> <message> <location line="+1"/> <source>Copy transaction ID</source> <translation>Copiar ID da Transação</translation> </message> <message> <location line="+1"/> <source>Edit label</source> <translation>Editar rótulo</translation> </message> <message> <location line="+1"/> <source>Show transaction details</source> <translation>Mostrar detalhes da transação</translation> </message> <message> <location line="+144"/> <source>Export Transaction Data</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Ficheiro separado por vírgula (*.csv)</translation> </message> <message> <location line="+8"/> <source>Confirmed</source> <translation>Confirmada</translation> </message> <message> <location line="+1"/> <source>Date</source> <translation>Data</translation> </message> <message> <location line="+1"/> <source>Type</source> <translation>Tipo</translation> </message> <message> <location line="+1"/> <source>Label</source> <translation>Rótulo</translation> </message> <message> <location line="+1"/> <source>Address</source> <translation>Endereço</translation> </message> <message> <location line="+1"/> <source>Amount</source> <translation>Quantia</translation> </message> <message> <location line="+1"/> <source>ID</source> <translation>ID</translation> </message> <message> <location line="+4"/> <source>Error exporting</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation type="unfinished"/> </message> <message> <location line="+100"/> <source>Range:</source> <translation>Período:</translation> </message> <message> <location line="+8"/> <source>to</source> <translation>até</translation> </message> </context> <context> <name>WalletModel</name> <message> <location filename="../walletmodel.cpp" line="+206"/> <source>Sending...</source> <translation type="unfinished"/> </message> </context> <context> <name>bitcoin-core</name> <message> <location filename="../bitcoinstrings.cpp" line="+33"/> <source>bitcoinlite version</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Usage:</source> <translation>Utilização:</translation> </message> <message> <location line="+1"/> <source>Send command to -server or bitcoinlited</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>List commands</source> <translation>Listar comandos</translation> </message> <message> <location line="+1"/> <source>Get help for a command</source> <translation>Obter ajuda para um comando</translation> </message> <message> <location line="+2"/> <source>Options:</source> <translation>Opções:</translation> </message> <message> <location line="+2"/> <source>Specify configuration file (default: bitcoinlite.conf)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Specify pid file (default: bitcoinlited.pid)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Specify wallet file (within data directory)</source> <translation>Especifique ficheiro de carteira (dentro da pasta de dados)</translation> </message> <message> <location line="-1"/> <source>Specify data directory</source> <translation>Especificar pasta de dados</translation> </message> <message> <location line="+2"/> <source>Set database cache size in megabytes (default: 25)</source> <translation>Definir o tamanho da cache de base de dados em megabytes (por defeito: 25)</translation> </message> <message> <location line="+1"/> <source>Set database disk log size in megabytes (default: 100)</source> <translation type="unfinished"/> </message> <message> <location line="+6"/> <source>Listen for connections on &lt;port&gt; (default: 15714 or testnet: 28756)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Maintain at most &lt;n&gt; connections to peers (default: 125)</source> <translation>Manter no máximo &lt;n&gt; ligações a outros nós da rede (por defeito: 125)</translation> </message> <message> <location line="+3"/> <source>Connect to a node to retrieve peer addresses, and disconnect</source> <translation>Ligar a um nó para recuperar endereços de pares, e desligar</translation> </message> <message> <location line="+1"/> <source>Specify your own public address</source> <translation>Especifique o seu endereço público</translation> </message> <message> <location line="+5"/> <source>Bind to given address. Use [host]:port notation for IPv6</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Stake your coins to support network and gain reward (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Threshold for disconnecting misbehaving peers (default: 100)</source> <translation>Tolerância para desligar nós mal-formados (por defeito: 100)</translation> </message> <message> <location line="+1"/> <source>Number of seconds to keep misbehaving peers from reconnecting (default: 86400)</source> <translation>Número de segundos a impedir que nós mal-formados se liguem de novo (por defeito: 86400)</translation> </message> <message> <location line="-44"/> <source>An error occurred while setting up the RPC port %u for listening on IPv4: %s</source> <translation>Ocorreu um erro ao definir a porta %u do serviço RPC a escutar em IPv4: %s</translation> </message> <message> <location line="+51"/> <source>Detach block and address databases. Increases shutdown time (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+109"/> <source>Error: The transaction was rejected. This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation type="unfinished"/> </message> <message> <location line="-5"/> <source>Error: This transaction requires a transaction fee of at least %s because of its amount, complexity, or use of recently received funds </source> <translation type="unfinished"/> </message> <message> <location line="-87"/> <source>Listen for JSON-RPC connections on &lt;port&gt; (default: 15715 or testnet: 28755)</source> <translation type="unfinished"/> </message> <message> <location line="-11"/> <source>Accept command line and JSON-RPC commands</source> <translation>Aceitar comandos da consola e JSON-RPC</translation> </message> <message> <location line="+101"/> <source>Error: Transaction creation failed </source> <translation type="unfinished"/> </message> <message> <location line="-5"/> <source>Error: Wallet locked, unable to create transaction </source> <translation type="unfinished"/> </message> <message> <location line="-8"/> <source>Importing blockchain data file.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Importing bootstrap blockchain data file.</source> <translation type="unfinished"/> </message> <message> <location line="-88"/> <source>Run in the background as a daemon and accept commands</source> <translation>Correr o processo como um daemon e aceitar comandos</translation> </message> <message> <location line="+1"/> <source>Use the test network</source> <translation>Utilizar a rede de testes - testnet</translation> </message> <message> <location line="-24"/> <source>Accept connections from outside (default: 1 if no -proxy or -connect)</source> <translation>Aceitar ligações externas (padrão: 1 sem -proxy ou -connect)</translation> </message> <message> <location line="-38"/> <source>An error occurred while setting up the RPC port %u for listening on IPv6, falling back to IPv4: %s</source> <translation>Ocorreu um erro ao definir a porta %u do serviço RPC a escutar em IPv6, a usar IPv4: %s</translation> </message> <message> <location line="+117"/> <source>Error initializing database environment %s! To recover, BACKUP THAT DIRECTORY, then remove everything from it except for wallet.dat.</source> <translation type="unfinished"/> </message> <message> <location line="-20"/> <source>Set maximum size of high-priority/low-fee transactions in bytes (default: 27000)</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Warning: -paytxfee is set very high! This is the transaction fee you will pay if you send a transaction.</source> <translation>Atenção: -paytxfee está definida com um valor muito alto! Esta é a taxa que irá pagar se enviar uma transação.</translation> </message> <message> <location line="+61"/> <source>Warning: Please check that your computer&apos;s date and time are correct! If your clock is wrong bitcoinlite will not work properly.</source> <translation type="unfinished"/> </message> <message> <location line="-31"/> <source>Warning: error reading wallet.dat! All keys read correctly, but transaction data or address book entries might be missing or incorrect.</source> <translation>Atenção: erro ao ler wallet.dat! Todas as chaves foram lidas correctamente, mas dados de transação ou do livro de endereços podem estar em falta ou incorrectos.</translation> </message> <message> <location line="-18"/> <source>Warning: wallet.dat corrupt, data salvaged! Original wallet.dat saved as wallet.{timestamp}.bak in %s; if your balance or transactions are incorrect you should restore from a backup.</source> <translation>Atenção: wallet.dat corrupto, dados recuperados! wallet.dat original salvo como wallet.{timestamp}.bak em %s; se o seu saldo ou transações estiverem incorrectos deverá recuperar de uma cópia de segurança.</translation> </message> <message> <location line="-30"/> <source>Attempt to recover private keys from a corrupt wallet.dat</source> <translation>Tentar recuperar chaves privadas de um wallet.dat corrupto</translation> </message> <message> <location line="+4"/> <source>Block creation options:</source> <translation>Opções de criação de bloco:</translation> </message> <message> <location line="-62"/> <source>Connect only to the specified node(s)</source> <translation>Apenas ligar ao(s) nó(s) especificado(s)</translation> </message> <message> <location line="+4"/> <source>Discover own IP address (default: 1 when listening and no -externalip)</source> <translation>Descobrir endereço IP próprio (padrão: 1 ao escutar e sem -externalip)</translation> </message> <message> <location line="+94"/> <source>Failed to listen on any port. Use -listen=0 if you want this.</source> <translation>Falhou a escutar em qualquer porta. Use -listen=0 se quer isto.</translation> </message> <message> <location line="-90"/> <source>Find peers using DNS lookup (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Sync checkpoints policy (default: strict)</source> <translation type="unfinished"/> </message> <message> <location line="+83"/> <source>Invalid -tor address: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Invalid amount for -reservebalance=&lt;amount&gt;</source> <translation type="unfinished"/> </message> <message> <location line="-82"/> <source>Maximum per-connection receive buffer, &lt;n&gt;*1000 bytes (default: 5000)</source> <translation>Armazenamento intermédio de recepção por ligação, &lt;n&gt;*1000 bytes (por defeito: 5000)</translation> </message> <message> <location line="+1"/> <source>Maximum per-connection send buffer, &lt;n&gt;*1000 bytes (default: 1000)</source> <translation>Armazenamento intermédio de envio por ligação, &lt;n&gt;*1000 bytes (por defeito: 1000)</translation> </message> <message> <location line="-16"/> <source>Only connect to nodes in network &lt;net&gt; (IPv4, IPv6 or Tor)</source> <translation>Apenas ligar a nós na rede &lt;net&gt; (IPv4, IPv6 ou Tor)</translation> </message> <message> <location line="+28"/> <source>Output extra debugging information. Implies all other -debug* options</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Output extra network debugging information</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Prepend debug output with timestamp</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>SSL options: (see the Bitcoin Wiki for SSL setup instructions)</source> <translation>Opções SSL: (ver a Wiki Bitcoin para instruções de configuração SSL)</translation> </message> <message> <location line="-74"/> <source>Select the version of socks proxy to use (4-5, default: 5)</source> <translation type="unfinished"/> </message> <message> <location line="+41"/> <source>Send trace/debug info to console instead of debug.log file</source> <translation>Enviar informação de rastreio/depuração para a consola e não para o ficheiro debug.log</translation> </message> <message> <location line="+1"/> <source>Send trace/debug info to debugger</source> <translation type="unfinished"/> </message> <message> <location line="+28"/> <source>Set maximum block size in bytes (default: 250000)</source> <translation type="unfinished"/> </message> <message> <location line="-1"/> <source>Set minimum block size in bytes (default: 0)</source> <translation>Definir tamanho minímo de um bloco em bytes (por defeito: 0)</translation> </message> <message> <location line="-29"/> <source>Shrink debug.log file on client startup (default: 1 when no -debug)</source> <translation>Encolher ficheiro debug.log ao iniciar o cliente (por defeito: 1 sem -debug definido)</translation> </message> <message> <location line="-42"/> <source>Specify connection timeout in milliseconds (default: 5000)</source> <translation>Especificar tempo de espera da ligação em millisegundos (por defeito: 5000)</translation> </message> <message> <location line="+109"/> <source>Unable to sign checkpoint, wrong checkpointkey? </source> <translation type="unfinished"/> </message> <message> <location line="-80"/> <source>Use UPnP to map the listening port (default: 0)</source> <translation>Usar UPnP para mapear a porta de escuta (padrão: 0)</translation> </message> <message> <location line="-1"/> <source>Use UPnP to map the listening port (default: 1 when listening)</source> <translation>Usar UPnP para mapear a porta de escuta (padrão: 1 ao escutar)</translation> </message> <message> <location line="-25"/> <source>Use proxy to reach tor hidden services (default: same as -proxy)</source> <translation type="unfinished"/> </message> <message> <location line="+42"/> <source>Username for JSON-RPC connections</source> <translation>Nome de utilizador para ligações JSON-RPC</translation> </message> <message> <location line="+47"/> <source>Verifying database integrity...</source> <translation type="unfinished"/> </message> <message> <location line="+57"/> <source>WARNING: syncronized checkpoint violation detected, but skipped!</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Warning: Disk space is low!</source> <translation type="unfinished"/> </message> <message> <location line="-2"/> <source>Warning: This version is obsolete, upgrade required!</source> <translation>Atenção: Esta versão está obsoleta, é necessário actualizar!</translation> </message> <message> <location line="-48"/> <source>wallet.dat corrupt, salvage failed</source> <translation>wallet.dat corrupta, recuperação falhou</translation> </message> <message> <location line="-54"/> <source>Password for JSON-RPC connections</source> <translation>Palavra-passe para ligações JSON-RPC</translation> </message> <message> <location line="-84"/> <source>%s, you must set a rpcpassword in the configuration file: %s It is recommended you use the following random password: rpcuser=bitcoinliterpc rpcpassword=%s (you do not need to remember this password) The username and password MUST NOT be the same. If the file does not exist, create it with owner-readable-only file permissions. It is also recommended to set alertnotify so you are notified of problems; for example: alertnotify=echo %%s | mail -s &quot;bitcoinlite Alert&quot; [email protected] </source> <translation type="unfinished"/> </message> <message> <location line="+51"/> <source>Find peers using internet relay chat (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Sync time with other nodes. Disable if time on your system is precise e.g. syncing with NTP (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>When creating transactions, ignore inputs with value less than this (default: 0.01)</source> <translation type="unfinished"/> </message> <message> <location line="+16"/> <source>Allow JSON-RPC connections from specified IP address</source> <translation>Permitir ligações JSON-RPC do endereço IP especificado</translation> </message> <message> <location line="+1"/> <source>Send commands to node running on &lt;ip&gt; (default: 127.0.0.1)</source> <translation>Enviar comandos para o nó a correr em &lt;ip&gt; (por defeito: 127.0.0.1)</translation> </message> <message> <location line="+1"/> <source>Execute command when the best block changes (%s in cmd is replaced by block hash)</source> <translation>Executar comando quando mudar o melhor bloco (no comando, %s é substituído pela hash do bloco)</translation> </message> <message> <location line="+3"/> <source>Execute command when a wallet transaction changes (%s in cmd is replaced by TxID)</source> <translation>Executar comando quando uma das transações na carteira mudar (no comando, %s é substituído pelo ID da Transação)</translation> </message> <message> <location line="+3"/> <source>Require a confirmations for change (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Enforce transaction scripts to use canonical PUSH operators (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Execute command when a relevant alert is received (%s in cmd is replaced by message)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Upgrade wallet to latest format</source> <translation>Atualize a carteira para o formato mais recente</translation> </message> <message> <location line="+1"/> <source>Set key pool size to &lt;n&gt; (default: 100)</source> <translation>Definir o tamanho da memória de chaves para &lt;n&gt; (por defeito: 100)</translation> </message> <message> <location line="+1"/> <source>Rescan the block chain for missing wallet transactions</source> <translation>Reexaminar a cadeia de blocos para transações em falta na carteira</translation> </message> <message> <location line="+2"/> <source>How many blocks to check at startup (default: 2500, 0 = all)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>How thorough the block verification is (0-6, default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Imports blocks from external blk000?.dat file</source> <translation type="unfinished"/> </message> <message> <location line="+8"/> <source>Use OpenSSL (https) for JSON-RPC connections</source> <translation>Usar OpenSSL (https) para ligações JSON-RPC</translation> </message> <message> <location line="+1"/> <source>Server certificate file (default: server.cert)</source> <translation>Ficheiro de certificado do servidor (por defeito: server.cert)</translation> </message> <message> <location line="+1"/> <source>Server private key (default: server.pem)</source> <translation>Chave privada do servidor (por defeito: server.pem)</translation> </message> <message> <location line="+1"/> <source>Acceptable ciphers (default: TLSv1+HIGH:!SSLv2:!aNULL:!eNULL:!AH:!3DES:@STRENGTH)</source> <translation type="unfinished"/> </message> <message> <location line="+53"/> <source>Error: Wallet unlocked for staking only, unable to create transaction.</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>WARNING: Invalid checkpoint found! Displayed transactions may not be correct! You may need to upgrade, or notify developers.</source> <translation type="unfinished"/> </message> <message> <location line="-158"/> <source>This help message</source> <translation>Esta mensagem de ajuda</translation> </message> <message> <location line="+95"/> <source>Wallet %s resides outside data directory %s.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Cannot obtain a lock on data directory %s. bitcoinlite is probably already running.</source> <translation type="unfinished"/> </message> <message> <location line="-98"/> <source>bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+140"/> <source>Unable to bind to %s on this computer (bind returned error %d, %s)</source> <translation>Incapaz de vincular a %s neste computador (vínculo retornou erro %d, %s)</translation> </message> <message> <location line="-130"/> <source>Connect through socks proxy</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Allow DNS lookups for -addnode, -seednode and -connect</source> <translation>Permitir procuras DNS para -addnode, -seednode e -connect</translation> </message> <message> <location line="+122"/> <source>Loading addresses...</source> <translation>Carregar endereços...</translation> </message> <message> <location line="-15"/> <source>Error loading blkindex.dat</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Error loading wallet.dat: Wallet corrupted</source> <translation>Erro ao carregar wallet.dat: Carteira danificada</translation> </message> <message> <location line="+4"/> <source>Error loading wallet.dat: Wallet requires newer version of bitcoinlite</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Wallet needed to be rewritten: restart bitcoinlite to complete</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Error loading wallet.dat</source> <translation>Erro ao carregar wallet.dat</translation> </message> <message> <location line="-16"/> <source>Invalid -proxy address: &apos;%s&apos;</source> <translation>Endereço -proxy inválido: &apos;%s&apos;</translation> </message> <message> <location line="-1"/> <source>Unknown network specified in -onlynet: &apos;%s&apos;</source> <translation>Rede desconhecida especificada em -onlynet: &apos;%s&apos;</translation> </message> <message> <location line="-1"/> <source>Unknown -socks proxy version requested: %i</source> <translation>Versão desconhecida de proxy -socks requisitada: %i</translation> </message> <message> <location line="+4"/> <source>Cannot resolve -bind address: &apos;%s&apos;</source> <translation>Não conseguiu resolver endereço -bind: &apos;%s&apos;</translation> </message> <message> <location line="+2"/> <source>Cannot resolve -externalip address: &apos;%s&apos;</source> <translation>Não conseguiu resolver endereço -externalip: &apos;%s&apos;</translation> </message> <message> <location line="-24"/> <source>Invalid amount for -paytxfee=&lt;amount&gt;: &apos;%s&apos;</source> <translation>Quantia inválida para -paytxfee=&lt;amount&gt;: &apos;%s&apos;</translation> </message> <message> <location line="+44"/> <source>Error: could not start node</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Sending...</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Invalid amount</source> <translation>Quantia inválida</translation> </message> <message> <location line="+1"/> <source>Insufficient funds</source> <translation>Fundos insuficientes</translation> </message> <message> <location line="-34"/> <source>Loading block index...</source> <translation>Carregar índice de blocos...</translation> </message> <message> <location line="-103"/> <source>Add a node to connect to and attempt to keep the connection open</source> <translation>Adicione um nó ao qual se ligar e tentar manter a ligação aberta</translation> </message> <message> <location line="+122"/> <source>Unable to bind to %s on this computer. bitcoinlite is probably already running.</source> <translation type="unfinished"/> </message> <message> <location line="-97"/> <source>Fee per KB to add to transactions you send</source> <translation type="unfinished"/> </message> <message> <location line="+55"/> <source>Invalid amount for -mininput=&lt;amount&gt;: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Loading wallet...</source> <translation>Carregar carteira...</translation> </message> <message> <location line="+8"/> <source>Cannot downgrade wallet</source> <translation>Impossível mudar a carteira para uma versão anterior</translation> </message> <message> <location line="+1"/> <source>Cannot initialize keypool</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Cannot write default address</source> <translation>Impossível escrever endereço por defeito</translation> </message> <message> <location line="+1"/> <source>Rescanning...</source> <translation>Reexaminando...</translation> </message> <message> <location line="+5"/> <source>Done loading</source> <translation>Carregamento completo</translation> </message> <message> <location line="-167"/> <source>To use the %s option</source> <translation>Para usar a opção %s</translation> </message> <message> <location line="+14"/> <source>Error</source> <translation>Erro</translation> </message> <message> <location line="+6"/> <source>You must set rpcpassword=&lt;password&gt; in the configuration file: %s If the file does not exist, create it with owner-readable-only file permissions.</source> <translation>Deverá definir rpcpassword=&lt;password&gt; no ficheiro de configuração: %s Se o ficheiro não existir, crie-o com permissões de leitura apenas para o dono.</translation> </message> </context> </TS><|fim▁end|>
<message> <location line="+6"/>
<|file_name|>test_Abstract_Factory_Pattern.py<|end_file_name|><|fim▁begin|># -*- coding:utf-8 -*- # @auth ivan # @time 2016-10-14 16:36:15 # @goal test Abstract Factory Pattern class Shape: def __init__(self): return <|fim▁hole|> class Circle(Shape): def draw(self): print("Inside Circle::draw() method.") class Rectangle(Shape): def draw(self): print("Inside Rectangle::draw() method.") class Square(Shape): def draw(self): print("Inside Square::draw() method.") class Color: def __init__(self): return def fill(self): return # Blue Green Red class Blue(Color): def fill(self): print("Inside Blue::fill() method.") class Green(Color): def fill(self): print("Inside Green::fill() method.") class Red(Color): def fill(self): print("Inside Red::fill() method.") class AbstractFactory: def __init__(self): return def getShape(self, shapeType): return def getColor(self, colorType): return # ShapeFactory ColorFactory class ColorFactory(AbstractFactory): def getColor(self, colorType): if not colorType: return elif colorType == 'BLUE': return Blue() elif colorType == 'GREEN': return Green() elif colorType == 'RED': return Red() return def getShape(self, shapeType): return class ShapeFactory(AbstractFactory): def getShape(self, shapeType): if not shapeType: return elif shapeType == 'CIRCLE': return Circle() elif shapeType == 'RECTANGLE': return Rectangle() elif shapeType == 'SQUARE': return Square() return def getColor(self, colorType): return class FactoryProducer: def getFactory(self, choice): if choice == 'SHAPE': return ShapeFactory() elif choice == 'COLOR': return ColorFactory() return class AbstractFactoryPatternDemo: def __init__(self): self.shapeFactory = FactoryProducer().getFactory("SHAPE") self.colorFactory = FactoryProducer().getFactory("COLOR") self.shape_list = ["CIRCLE", "RECTANGLE", "SQUARE"] self.color_list = ["BLUE", "GREEN", "RED"] def run(self): for i in self.shape_list: shape = self.shapeFactory.getShape(i) shape.draw() for i in self.color_list: color1 = self.colorFactory.getColor(i) color1.fill() A = AbstractFactoryPatternDemo() A.run()<|fim▁end|>
def draw(self): return # Circle Rectangle Square
<|file_name|>fn6.js<|end_file_name|><|fim▁begin|>{<|fim▁hole|> "name": "fn6.js", "url": "https://github.com/stefanwimmer128/fn6.js.git" }<|fim▁end|>
<|file_name|>ForwardDependenciesBuilder.java<|end_file_name|><|fim▁begin|>/* * Copyright 2000-2009 JetBrains s.r.o. * * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this file except in compliance with the License. * You may obtain a copy of the License at * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ package com.intellij.packageDependencies; import com.intellij.analysis.AnalysisScope; import com.intellij.analysis.AnalysisScopeBundle; import com.intellij.lang.injection.InjectedLanguageManager; import com.intellij.openapi.progress.ProcessCanceledException; import com.intellij.openapi.progress.ProgressIndicator; import com.intellij.openapi.progress.ProgressManager; import com.intellij.openapi.project.Project; import com.intellij.openapi.roots.ProjectFileIndex; import com.intellij.openapi.roots.ProjectRootManager; import com.intellij.openapi.vfs.VirtualFile; import com.intellij.psi.*; import org.jetbrains.annotations.NotNull; import java.util.HashMap; import java.util.HashSet; import java.util.Map; import java.util.Set; public class ForwardDependenciesBuilder extends DependenciesBuilder { private final Map<PsiFile, Set<PsiFile>> myDirectDependencies = new HashMap<PsiFile, Set<PsiFile>>(); public ForwardDependenciesBuilder(@NotNull Project project, @NotNull AnalysisScope scope) { super(project, scope); } public ForwardDependenciesBuilder(final Project project, final AnalysisScope scope, final AnalysisScope scopeOfInterest) { super(project, scope, scopeOfInterest); } public ForwardDependenciesBuilder(final Project project, final AnalysisScope scope, final int transitive) { super(project, scope); myTransitive = transitive; } @Override public String getRootNodeNameInUsageView(){ return AnalysisScopeBundle.message("forward.dependencies.usage.view.root.node.text"); } @Override public String getInitialUsagesPosition(){ return AnalysisScopeBundle.message("forward.dependencies.usage.view.initial.text"); } @Override public boolean isBackward(){ return false; } @Override public void analyze() { final PsiManager psiManager = PsiManager.getInstance(getProject()); psiManager.startBatchFilesProcessingMode(); final ProjectFileIndex fileIndex = ProjectRootManager.getInstance(getProject()).getFileIndex(); try { getScope().accept(new PsiRecursiveElementVisitor() { @Override public void visitFile(final PsiFile file) { visit(file, fileIndex, psiManager, 0); } }); } finally { psiManager.finishBatchFilesProcessingMode(); } } private void visit(final PsiFile file, final ProjectFileIndex fileIndex, final PsiManager psiManager, int depth) { final FileViewProvider viewProvider = file.getViewProvider(); if (viewProvider.getBaseLanguage() != file.getLanguage()) return; if (getScopeOfInterest() != null && !getScopeOfInterest().contains(file)) return; ProgressIndicator indicator = ProgressManager.getInstance().getProgressIndicator(); final VirtualFile virtualFile = file.getVirtualFile(); if (indicator != null) { if (indicator.isCanceled()) { throw new ProcessCanceledException(); } indicator.setText(AnalysisScopeBundle.message("package.dependencies.progress.text")); if (virtualFile != null) { indicator.setText2(getRelativeToProjectPath(virtualFile)); } if ( myTotalFileCount > 0) { indicator.setFraction(((double)++ myFileCount) / myTotalFileCount); } } final boolean isInLibrary = virtualFile == null || fileIndex.isInLibrarySource(virtualFile) || fileIndex.isInLibraryClasses(virtualFile); final Set<PsiFile> collectedDeps = new HashSet<PsiFile>(); final HashSet<PsiFile> processed = new HashSet<PsiFile>(); collectedDeps.add(file); do { if (depth++ > getTransitiveBorder()) return; for (PsiFile psiFile : new HashSet<PsiFile>(collectedDeps)) { final VirtualFile vFile = psiFile.getVirtualFile();<|fim▁hole|> indicator.setText2(getRelativeToProjectPath(vFile)); } if (!isInLibrary && (fileIndex.isInLibraryClasses(vFile) || fileIndex.isInLibrarySource(vFile))) { processed.add(psiFile); } } final Set<PsiFile> found = new HashSet<PsiFile>(); if (!processed.contains(psiFile)) { processed.add(psiFile); analyzeFileDependencies(psiFile, new DependencyProcessor() { @Override public void process(PsiElement place, PsiElement dependency) { PsiFile dependencyFile = dependency.getContainingFile(); if (dependencyFile != null) { if (viewProvider == dependencyFile.getViewProvider()) return; if (dependencyFile.isPhysical()) { final VirtualFile virtualFile = dependencyFile.getVirtualFile(); if (virtualFile != null && (fileIndex.isInContent(virtualFile) || fileIndex.isInLibraryClasses(virtualFile) || fileIndex.isInLibrarySource(virtualFile))) { found.add(dependencyFile); } } } } }); Set<PsiFile> deps = getDependencies().get(file); if (deps == null) { deps = new HashSet<PsiFile>(); getDependencies().put(file, deps); } deps.addAll(found); getDirectDependencies().put(psiFile, new HashSet<PsiFile>(found)); collectedDeps.addAll(found); psiManager.dropResolveCaches(); InjectedLanguageManager.getInstance(file.getProject()).dropFileCaches(file); } } collectedDeps.removeAll(processed); } while (isTransitive() && !collectedDeps.isEmpty()); } @Override public Map<PsiFile, Set<PsiFile>> getDirectDependencies() { return myDirectDependencies; } }<|fim▁end|>
if (vFile != null) { if (indicator != null) {
<|file_name|>error.rs<|end_file_name|><|fim▁begin|>//! Error manipulations. use std::error::Error; use std::ffi::{self, CStr}; use std::fmt; use std::ptr; use std::sync::Arc; use rdkafka_sys as rdsys; use rdkafka_sys::types::*; use crate::util::{KafkaDrop, NativePtr}; // Re-export rdkafka error code pub use rdsys::types::RDKafkaErrorCode; /// Kafka result. pub type KafkaResult<T> = Result<T, KafkaError>; /// Verify if the value represents an error condition. /// /// Some librdkafka codes are informational, rather than true errors. pub trait IsError { /// Reports whether the value represents an error. fn is_error(&self) -> bool; } impl IsError for RDKafkaRespErr { fn is_error(&self) -> bool { *self as i32 != RDKafkaRespErr::RD_KAFKA_RESP_ERR_NO_ERROR as i32 } } impl IsError for RDKafkaConfRes { fn is_error(&self) -> bool { *self as i32 != RDKafkaConfRes::RD_KAFKA_CONF_OK as i32 } } impl IsError for RDKafkaError { fn is_error(&self) -> bool { self.0.is_some() } } /// Native rdkafka error. #[derive(Clone)] pub struct RDKafkaError(Option<Arc<NativePtr<rdsys::rd_kafka_error_t>>>); unsafe impl KafkaDrop for rdsys::rd_kafka_error_t { const TYPE: &'static str = "error"; const DROP: unsafe extern "C" fn(*mut Self) = rdsys::rd_kafka_error_destroy; } unsafe impl Send for RDKafkaError {} unsafe impl Sync for RDKafkaError {} impl RDKafkaError { pub(crate) unsafe fn from_ptr(ptr: *mut rdsys::rd_kafka_error_t) -> RDKafkaError { RDKafkaError(NativePtr::from_ptr(ptr).map(Arc::new)) } fn ptr(&self) -> *const rdsys::rd_kafka_error_t { match &self.0 { None => ptr::null(), Some(p) => p.ptr(), } } /// Returns the error code or [`RDKafkaErrorCode::NoError`] if the error is /// null. pub fn code(&self) -> RDKafkaErrorCode { unsafe { rdsys::rd_kafka_error_code(self.ptr()).into() } } /// Returns the error code name, e.g., "ERR_UNKNOWN_MEMBER_ID" or an empty /// string if the error is null. pub fn name(&self) -> String { let cstr = unsafe { rdsys::rd_kafka_error_name(self.ptr()) }; unsafe { CStr::from_ptr(cstr).to_string_lossy().into_owned() } } /// Returns a human readable error string or an empty string if the error is /// null. pub fn string(&self) -> String { let cstr = unsafe { rdsys::rd_kafka_error_string(self.ptr()) }; unsafe { CStr::from_ptr(cstr).to_string_lossy().into_owned() } } /// Reports whether the error is a fatal error. /// /// A fatal error indicates that the client instance is no longer usable. pub fn is_fatal(&self) -> bool { unsafe { rdsys::rd_kafka_error_is_fatal(self.ptr()) != 0 } } /// Reports whether the operation that encountered the error can be retried. pub fn is_retriable(&self) -> bool { unsafe { rdsys::rd_kafka_error_is_retriable(self.ptr()) != 0 } } /// Reports whether the error is an abortable transaction error. pub fn txn_requires_abort(&self) -> bool { unsafe { rdsys::rd_kafka_error_txn_requires_abort(self.ptr()) != 0 } } } impl PartialEq for RDKafkaError { fn eq(&self, other: &RDKafkaError) -> bool { self.code() == other.code() } } impl Eq for RDKafkaError {} impl fmt::Debug for RDKafkaError { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result { write!(f, "RDKafkaError({})", self) } } impl fmt::Display for RDKafkaError { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result { f.write_str(&self.string()) } } impl Error for RDKafkaError {} // TODO: consider using macro /// Represents all possible Kafka errors. /// /// If applicable, check the underlying [`RDKafkaErrorCode`] to get details. #[derive(Clone, PartialEq, Eq)] #[non_exhaustive] pub enum KafkaError { /// Creation of admin operation failed. AdminOpCreation(String), /// The admin operation itself failed. AdminOp(RDKafkaErrorCode), /// The client was dropped before the operation completed. Canceled, /// Invalid client configuration. ClientConfig(RDKafkaConfRes, String, String, String), /// Client creation failed. ClientCreation(String), /// Consumer commit failed. ConsumerCommit(RDKafkaErrorCode), /// Global error. Global(RDKafkaErrorCode), /// Group list fetch failed. GroupListFetch(RDKafkaErrorCode), /// Message consumption failed. MessageConsumption(RDKafkaErrorCode), /// Message production error. MessageProduction(RDKafkaErrorCode), /// Metadata fetch error. MetadataFetch(RDKafkaErrorCode), /// No message was received. NoMessageReceived, /// Unexpected null pointer Nul(ffi::NulError), /// Offset fetch failed. OffsetFetch(RDKafkaErrorCode), /// End of partition reached. PartitionEOF(i32), /// Pause/Resume failed. PauseResume(String), /// Seeking a partition failed. Seek(String), /// Setting partition offset failed. SetPartitionOffset(RDKafkaErrorCode), /// Offset store failed. StoreOffset(RDKafkaErrorCode), /// Subscription creation failed. Subscription(String), /// Transaction error. Transaction(RDKafkaError),<|fim▁hole|>impl fmt::Debug for KafkaError { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result { match self { KafkaError::AdminOp(err) => write!(f, "KafkaError (Admin operation error: {})", err), KafkaError::AdminOpCreation(ref err) => { write!(f, "KafkaError (Admin operation creation error: {})", err) } KafkaError::Canceled => write!(f, "KafkaError (Client dropped)"), KafkaError::ClientConfig(_, ref desc, ref key, ref value) => write!( f, "KafkaError (Client config error: {} {} {})", desc, key, value ), KafkaError::ClientCreation(ref err) => { write!(f, "KafkaError (Client creation error: {})", err) } KafkaError::ConsumerCommit(err) => { write!(f, "KafkaError (Consumer commit error: {})", err) } KafkaError::Global(err) => write!(f, "KafkaError (Global error: {})", err), KafkaError::GroupListFetch(err) => { write!(f, "KafkaError (Group list fetch error: {})", err) } KafkaError::MessageConsumption(err) => { write!(f, "KafkaError (Message consumption error: {})", err) } KafkaError::MessageProduction(err) => { write!(f, "KafkaError (Message production error: {})", err) } KafkaError::MetadataFetch(err) => { write!(f, "KafkaError (Metadata fetch error: {})", err) } KafkaError::NoMessageReceived => { write!(f, "No message received within the given poll interval") } KafkaError::Nul(_) => write!(f, "FFI null error"), KafkaError::OffsetFetch(err) => write!(f, "KafkaError (Offset fetch error: {})", err), KafkaError::PartitionEOF(part_n) => write!(f, "KafkaError (Partition EOF: {})", part_n), KafkaError::PauseResume(ref err) => { write!(f, "KafkaError (Pause/resume error: {})", err) } KafkaError::Seek(ref err) => write!(f, "KafkaError (Seek error: {})", err), KafkaError::SetPartitionOffset(err) => { write!(f, "KafkaError (Set partition offset error: {})", err) } KafkaError::StoreOffset(err) => write!(f, "KafkaError (Store offset error: {})", err), KafkaError::Subscription(ref err) => { write!(f, "KafkaError (Subscription error: {})", err) } KafkaError::Transaction(err) => write!(f, "KafkaError (Transaction error: {})", err), } } } impl fmt::Display for KafkaError { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> fmt::Result { match self { KafkaError::AdminOp(err) => write!(f, "Admin operation error: {}", err), KafkaError::AdminOpCreation(ref err) => { write!(f, "Admin operation creation error: {}", err) } KafkaError::Canceled => write!(f, "KafkaError (Client dropped)"), KafkaError::ClientConfig(_, ref desc, ref key, ref value) => { write!(f, "Client config error: {} {} {}", desc, key, value) } KafkaError::ClientCreation(ref err) => write!(f, "Client creation error: {}", err), KafkaError::ConsumerCommit(err) => write!(f, "Consumer commit error: {}", err), KafkaError::Global(err) => write!(f, "Global error: {}", err), KafkaError::GroupListFetch(err) => write!(f, "Group list fetch error: {}", err), KafkaError::MessageConsumption(err) => write!(f, "Message consumption error: {}", err), KafkaError::MessageProduction(err) => write!(f, "Message production error: {}", err), KafkaError::MetadataFetch(err) => write!(f, "Meta data fetch error: {}", err), KafkaError::NoMessageReceived => { write!(f, "No message received within the given poll interval") } KafkaError::Nul(_) => write!(f, "FFI nul error"), KafkaError::OffsetFetch(err) => write!(f, "Offset fetch error: {}", err), KafkaError::PartitionEOF(part_n) => write!(f, "Partition EOF: {}", part_n), KafkaError::PauseResume(ref err) => write!(f, "Pause/resume error: {}", err), KafkaError::Seek(ref err) => write!(f, "Seek error: {}", err), KafkaError::SetPartitionOffset(err) => write!(f, "Set partition offset error: {}", err), KafkaError::StoreOffset(err) => write!(f, "Store offset error: {}", err), KafkaError::Subscription(ref err) => write!(f, "Subscription error: {}", err), KafkaError::Transaction(err) => write!(f, "Transaction error: {}", err), } } } impl Error for KafkaError { fn source(&self) -> Option<&(dyn Error + 'static)> { match self { KafkaError::AdminOp(_) => None, KafkaError::AdminOpCreation(_) => None, KafkaError::Canceled => None, KafkaError::ClientConfig(..) => None, KafkaError::ClientCreation(_) => None, KafkaError::ConsumerCommit(err) => Some(err), KafkaError::Global(err) => Some(err), KafkaError::GroupListFetch(err) => Some(err), KafkaError::MessageConsumption(err) => Some(err), KafkaError::MessageProduction(err) => Some(err), KafkaError::MetadataFetch(err) => Some(err), KafkaError::NoMessageReceived => None, KafkaError::Nul(_) => None, KafkaError::OffsetFetch(err) => Some(err), KafkaError::PartitionEOF(_) => None, KafkaError::PauseResume(_) => None, KafkaError::Seek(_) => None, KafkaError::SetPartitionOffset(err) => Some(err), KafkaError::StoreOffset(err) => Some(err), KafkaError::Subscription(_) => None, KafkaError::Transaction(err) => Some(err), } } } impl From<ffi::NulError> for KafkaError { fn from(err: ffi::NulError) -> KafkaError { KafkaError::Nul(err) } } impl KafkaError { /// Returns the [`RDKafkaErrorCode`] underlying this error, if any. #[allow(clippy::match_same_arms)] pub fn rdkafka_error_code(&self) -> Option<RDKafkaErrorCode> { match self { KafkaError::AdminOp(_) => None, KafkaError::AdminOpCreation(_) => None, KafkaError::Canceled => None, KafkaError::ClientConfig(..) => None, KafkaError::ClientCreation(_) => None, KafkaError::ConsumerCommit(err) => Some(*err), KafkaError::Global(err) => Some(*err), KafkaError::GroupListFetch(err) => Some(*err), KafkaError::MessageConsumption(err) => Some(*err), KafkaError::MessageProduction(err) => Some(*err), KafkaError::MetadataFetch(err) => Some(*err), KafkaError::NoMessageReceived => None, KafkaError::Nul(_) => None, KafkaError::OffsetFetch(err) => Some(*err), KafkaError::PartitionEOF(_) => None, KafkaError::PauseResume(_) => None, KafkaError::Seek(_) => None, KafkaError::SetPartitionOffset(err) => Some(*err), KafkaError::StoreOffset(err) => Some(*err), KafkaError::Subscription(_) => None, KafkaError::Transaction(err) => Some(err.code()), } } }<|fim▁end|>
}
<|file_name|>lab.py<|end_file_name|><|fim▁begin|>import cryspy.numbers import cryspy.geo class Goniometer: def __init__(self, motiontype, axis, direction, parametername): assert motiontype in ["translation", "rotation"], \ "First parameter for creating a Goniometer " \ "must be one of the strings " \ "'translation' or 'rotation'." assert axis in ["x", "y", "z"], \ "Second parameter for creating a Goniometer " \ "must be one of the strings 'x', 'y' or 'z'" if motiontype == "translation": assert direction in ["positive", "negative"], \ "Third parameter for creating a Goniometer " \ "for translation must be one of the strings " \ "'positive' or 'negative'" elif motiontype == "rotation": assert direction in ["clockwise", "counterclockwise"], \ "Third parameter for creating a Goniometer for " \ "rotation must be one of the strings "\ "'clockwise' or 'counterclockwise'" assert isinstance(parametername, str), \ "Fourth parameter for creating a Goniometer must be " \ "of type str. You can use any string." self.composed = False self.motiontype = motiontype self.axis = axis self.direction = direction self.parameternames = [parametername] def operator(self, parameters): assert isinstance(parameters, dict), \ "Parameter of cryspy.lab.Goniometer.operator() must be a " \ "dictionary" if not self.composed:<|fim▁hole|> assert self.parameternames[0] in parameters.keys(), \ "You must specify the parameter called '%s'."\ %(self.parameternames[0]) parameter = parameters[self.parameternames[0]] if self.motiontype == "translation": if self.direction == "negative": parameter = -parameter if self.axis == "x": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[1, 0, 0, parameter], [0, 1, 0, 0], [0, 0, 1, 0], [0, 0, 0, 1] ] ) ) if self.axis == "y": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[1, 0, 0, 0], [0, 1, 0, parameter], [0, 0, 1, 0], [0, 0, 0, 1] ] ) ) if self.axis == "z": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[1, 0, 0, 0], [0, 1, 0, 0], [0, 0, 1, parameter], [0, 0, 0, 1] ] ) ) elif self.motiontype == "rotation": if self.direction == "clockwise": parameter = -parameter cos = cryspy.numbers.dcos(parameter) sin = cryspy.numbers.dsin(parameter) if self.axis == "x": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[1, 0, 0, 0], [0, cos, -sin, 0], [0, sin, cos, 0], [0, 0, 0, 1] ] ) ) if self.axis == "y": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[ cos, 0, sin, 0], [ 0, 1, 0, 0], [-sin, 0, cos, 0], [ 0, 0, 0, 1] ] ) ) if self.axis == "z": return cryspy.geo.Operator( cryspy.numbers.Matrix( [[cos, -sin, 0, 0], [sin, cos, 0, 0], [ 0, 0, 1, 0], [ 0, 0, 0, 1] ] ) ) else: return cryspy.geo.Operator( self.lower_gonio.operator(parameters).value * self.upper_gonio.operator(parameters).value ) def __str__(self): if not self.composed: if self.motiontype == "translation": return " / translate by \\ \n" \ "| %16s |\n" \ "| along |\n" \ "| %s-axis |\n" \ " \\ %8s / "\ %(self.parameternames[0], self.axis, self.direction) elif self.motiontype == "rotation": return " / rotate by \\ \n" \ "| %16s |\n" \ "| around |\n" \ "| %s-axis |\n" \ " \\ %16s / "\ %(self.parameternames[0], self.axis, self.direction) else: return cryspy.blockprint.block([[str(self.lower_gonio), " \n \n*\n \n", str(self.upper_gonio)]]) def __mul__(self, right): if isinstance(right, Goniometer): for parametername in right.parameternames: assert parametername not in self.parameternames, \ "Cannot multiply two Goniometers which have " \ "both the parameter '%s'."%(parametername) result = Goniometer("translation", "x", "positive", "dummy") result.composed = True result.motiontype = None result.axis = None result.direction = None result.parameternames = self.parameternames + right.parameternames result.lower_gonio = self result.upper_gonio = right return result else: return NotImplemented<|fim▁end|>
# assert len(parameters) == 1, \ # "A Goniometer which is not composed can have only one " \ # "parameter." # parametername = list(parameters.keys())[0]
<|file_name|>attributes.py<|end_file_name|><|fim▁begin|>from __future__ import (absolute_import, division, print_function, unicode_literals) from prov.model import * EX_NS = Namespace('ex', 'http://example.org/') EX_OTHER_NS = Namespace('other', 'http://example.org/') class TestAttributesBase(object): """This is the base class for testing support for various datatypes. It is not runnable and needs to be included in a subclass of RoundTripTestCase. """ attribute_values = [ "un lieu", Literal("un lieu", langtag='fr'), Literal("a place", langtag='en'), Literal(1, XSD_INT), Literal(1, XSD_LONG), Literal(1, XSD_SHORT), Literal(2.0, XSD_DOUBLE), Literal(1.0, XSD_FLOAT), Literal(10, XSD_DECIMAL), True, False, Literal(10, XSD_BYTE), Literal(10, XSD_UNSIGNEDINT), Literal(10, XSD_UNSIGNEDLONG), Literal(10, XSD_INTEGER), Literal(10, XSD_UNSIGNEDSHORT), Literal(10, XSD_NONNEGATIVEINTEGER), Literal(-10, XSD_NONPOSITIVEINTEGER), Literal(10, XSD_POSITIVEINTEGER), Literal(10, XSD_UNSIGNEDBYTE), Identifier('http://example.org'), Literal('http://example.org', XSD_ANYURI), EX_NS['abc'], EX_OTHER_NS['abcd'], Namespace('ex', 'http://example4.org/')['zabc'], Namespace('other', 'http://example4.org/')['zabcd'], datetime.datetime.now(), Literal(datetime.datetime.now().isoformat(), XSD_DATETIME) ] def new_document(self): return ProvDocument() def run_entity_with_one_type_attribute(self, n): document = self.new_document() document.entity(EX_NS['et%d' % n], {'prov:type': self.attribute_values[n]}) self.assertRoundTripEquivalence(document) def test_entity_with_one_type_attribute_0(self): self.run_entity_with_one_type_attribute(0) def test_entity_with_one_type_attribute_1(self): self.run_entity_with_one_type_attribute(1) def test_entity_with_one_type_attribute_2(self): self.run_entity_with_one_type_attribute(2) def test_entity_with_one_type_attribute_3(self): self.run_entity_with_one_type_attribute(3) def test_entity_with_one_type_attribute_4(self): self.run_entity_with_one_type_attribute(4) def test_entity_with_one_type_attribute_5(self): self.run_entity_with_one_type_attribute(5) def test_entity_with_one_type_attribute_6(self): self.run_entity_with_one_type_attribute(6) def test_entity_with_one_type_attribute_7(self): self.run_entity_with_one_type_attribute(7) def test_entity_with_one_type_attribute_8(self): self.run_entity_with_one_type_attribute(8) def test_entity_with_one_type_attribute_9(self): self.run_entity_with_one_type_attribute(9) def test_entity_with_one_type_attribute_10(self): self.run_entity_with_one_type_attribute(10) def test_entity_with_one_type_attribute_11(self): self.run_entity_with_one_type_attribute(11) def test_entity_with_one_type_attribute_12(self): self.run_entity_with_one_type_attribute(12) def test_entity_with_one_type_attribute_13(self): self.run_entity_with_one_type_attribute(13) def test_entity_with_one_type_attribute_14(self): self.run_entity_with_one_type_attribute(14) def test_entity_with_one_type_attribute_15(self): self.run_entity_with_one_type_attribute(15) def test_entity_with_one_type_attribute_16(self): self.run_entity_with_one_type_attribute(16) def test_entity_with_one_type_attribute_17(self): self.run_entity_with_one_type_attribute(17) def test_entity_with_one_type_attribute_18(self): self.run_entity_with_one_type_attribute(18) def test_entity_with_one_type_attribute_19(self): self.run_entity_with_one_type_attribute(19) def test_entity_with_one_type_attribute_20(self): self.run_entity_with_one_type_attribute(20) def test_entity_with_one_type_attribute_21(self): self.run_entity_with_one_type_attribute(21) def test_entity_with_one_type_attribute_22(self): self.run_entity_with_one_type_attribute(22) def test_entity_with_one_type_attribute_23(self): self.run_entity_with_one_type_attribute(23) def test_entity_with_one_type_attribute_24(self): self.run_entity_with_one_type_attribute(24) <|fim▁hole|> self.run_entity_with_one_type_attribute(25) def test_entity_with_one_type_attribute_26(self): self.run_entity_with_one_type_attribute(26) def test_entity_with_one_type_attribute_27(self): self.run_entity_with_one_type_attribute(27) def test_entity_with_multiple_attribute(self): document = self.new_document() attributes = [ (EX_NS['v_%d'% i], value) for i, value in enumerate(self.attribute_values) ] document.entity(EX_NS['emov'], attributes) self.assertRoundTripEquivalence(document) def test_entity_with_multiple_value_attribute(self): document = self.new_document() attributes = [ ('prov:value', value) for i, value in enumerate(self.attribute_values) ] document.entity(EX_NS['emv'], attributes) self.assertRoundTripEquivalence(document)<|fim▁end|>
def test_entity_with_one_type_attribute_25(self):
<|file_name|>__init__.py<|end_file_name|><|fim▁begin|># -*- encoding: utf-8 -*- ############################################################################## # # OpenERP, Open Source Management Solution # # Copyright (c) 2013-2015 Noviat nv/sa (www.noviat.com). # # This program is free software: you can redistribute it and/or modify # it under the terms of the GNU Affero General Public License as # published by the Free Software Foundation, either version 3 of the # License, or (at your option) any later version. # # This program is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the # GNU Affero General Public License for more details. # # You should have received a copy of the GNU Affero General Public License # along with this program. If not, see <http://www.gnu.org/licenses/>.<|fim▁hole|>from . import res_partner from . import ir_actions<|fim▁end|>
# ############################################################################## from . import account
<|file_name|>optimize.js<|end_file_name|><|fim▁begin|>/** * Created by joonkukang on 2014. 1. 16.. */ var math = require('./utils').math; let optimize = module.exports; optimize.hillclimb = function(options){ var domain = options['domain']; var costf = options['costf']; var i; var vec = []; for(i=0 ; i<domain.length ; i++) vec.push(math.randInt(domain[i][0],domain[i][1])); var current, best; while(true) { var neighbors = []; var i,j; for(i=0 ; i<domain.length ; i++) { if(vec[i] > domain[i][0]) { var newVec = []; for(j=0 ; j<domain.length ; j++) newVec.push(vec[j]); newVec[i]-=1; neighbors.push(newVec); } else if (vec[i] < domain[i][1]) { var newVec = []; for(j=0 ; j<domain.length ; j++) newVec.push(vec[j]); newVec[i]+=1; neighbors.push(newVec); } } current = costf(vec); best = current; for(i=0 ; i<neighbors.length ; i++) { var cost = costf(neighbors[i]); if(cost < best) { best = cost; vec = neighbors[i]; } } if(best === current) break; } return vec; } optimize.anneal = function(options){ var domain = options['domain']; var costf = options['costf']; var temperature = options['temperature']; var cool = options['cool']; var step = options['step']; var callback var i; var vec = []; for(i=0 ; i<domain.length ; i++) vec.push(math.randInt(domain[i][0],domain[i][1])); while(temperature > 0.1) { var idx = math.randInt(0,domain.length - 1); var dir = math.randInt(-step,step); var newVec = []; for(i=0; i<vec.length ; i++) newVec.push(vec[i]); newVec[idx]+=dir; if(newVec[idx] < domain[idx][0]) newVec[idx] = domain[idx][0]; if(newVec[idx] > domain[idx][1]) newVec[idx] = domain[idx][1]; var ea = costf(vec); var eb = costf(newVec); var p = Math.exp(-1.*(eb-ea)/temperature); if(eb < ea || Math.random() < p) vec = newVec; temperature *= cool; } return vec; } optimize.genetic = function(options){ var domain = options['domain']; var costf = options['costf']; var population = options['population']; var q = options['q'] || 0.3; var elite = options['elite'] || population * 0.04; var epochs = options['epochs'] || 100; var i,j; // Initialize population array var pop =[]; for(i=0; i<population; i++) { var vec = []; for(j=0; j<domain.length; j++) vec.push(math.randInt(domain[j][0],domain[j][1])); pop.push(vec); } pop.sort(function(a,b){return costf(a) - costf(b);}); for(i=0 ; i<epochs ; i++) { // elitism var newPop = []; for(j=0;j<elite;j++) newPop.push(pop[j]); // compute fitnesses var fitnesses = []; for(j=0; j<pop.length; j++) fitnesses[j] = q * Math.pow(1-q,j); fitnesses = math.normalizeVec(fitnesses); // crossover, mutate for(j=0; j<pop.length - elite;j++) { var idx1 = rouletteWheel(fitnesses); var idx2 = rouletteWheel(fitnesses); var crossovered = crossover(pop[idx1],pop[idx2]); var mutated = mutate(crossovered); newPop.push(mutated); } // replacement pop = newPop; pop.sort(function(a,b){return costf(a) - costf(b);}); //console.log("Current Cost : ",costf(pop[0])); } return pop[0]; function mutate(vec) { var idx = math.randInt(0,domain.length - 1); var newVec = []; var i; for(i=0; i<domain.length ; i++)<|fim▁hole|> newVec[idx] += (Math.random() < 0.5) ? 1 : -1; if(newVec[idx] < domain[idx][0]) newVec[idx] = domain[idx][0]; if(newVec[idx] > domain[idx][1]) newVec[idx] = domain[idx][1]; return newVec; } function crossover(vec1,vec2) { var idx = math.randInt(0,domain.length - 2); var newVec = []; var i; for(i=0; i<idx ; i++) newVec.push(vec1[i]); for(i=idx; i<domain.length; i++) newVec.push(vec2[i]); return newVec; } function rouletteWheel(vec) { var a = [0.0]; var i; for(i=0;i<vec.length;i++) { a.push(a[i] + vec[i]); } var rand = Math.random(); for(i=0;i< a.length;i++) { if(rand > a[i] && rand <= a[i+1]) return i; } return -1; } };<|fim▁end|>
newVec.push(vec[i]);
<|file_name|>output.py<|end_file_name|><|fim▁begin|># Copyright 2015 Isotoma Limited # # Licensed under the Apache License, Version 2.0 (the "License"); # you may not use this file except in compliance with the License. # You may obtain a copy of the License at # # http://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, # WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. # See the License for the specific language governing permissions and # limitations under the License. from touchdown.core import argument, resource, serializers from .provisioner import Provisioner <|fim▁hole|>class Output(resource.Resource): resource_name = "output" name = argument.String() provisioner = argument.Resource(Provisioner) class OutputAsString(serializers.Serializer): def __init__(self, resource): self.resource = resource def render(self, runner, object): if self.pending(runner, object): return serializers.Pending(self.resource) # Extract the contents from the file on the (potentially remote) target service = runner.get_service(self.resource.provisioner.target, "describe") client = service.get_client() return client.get_path_contents(self.resource.name) def pending(self, runner, object): provisioner = runner.get_service(self.resource.provisioner, "apply") return provisioner.object["Result"] == "Pending" def dependencies(self, object): return frozenset((self.resource,)) argument.String.register_adapter(Output, lambda r: OutputAsString(r)) class OutputAsBytes(serializers.Serializer): def __init__(self, resource): self.resource = resource def render(self, runner, object): if self.pending(runner, object): return serializers.Pending(self.resource) # Extract the contents from the file on the (potentially remote) target service = runner.get_service(self.resource.provisioner.target, "describe") client = service.get_client() return client.get_path_bytes(self.resource.name) def pending(self, runner, object): provisioner = runner.get_service(self.resource.provisioner, "apply") return provisioner.object["Result"] == "Pending" def dependencies(self, object): return frozenset((self.resource,)) argument.Bytes.register_adapter(Output, lambda r: OutputAsBytes(r))<|fim▁end|>
<|file_name|>class-super.py<|end_file_name|><|fim▁begin|>class Base: def meth(self): print("in Base meth") class Sub(Base): def meth(self):<|fim▁hole|> print("in Sub meth") return super().meth() a = Sub() a.meth()<|fim▁end|>
<|file_name|>em_bridge_lifecycle_states.go<|end_file_name|><|fim▁begin|>// Copyright (c) 2016, 2018, 2021, Oracle and/or its affiliates. All rights reserved. // This software is dual-licensed to you under the Universal Permissive License (UPL) 1.0 as shown at https://oss.oracle.com/licenses/upl or Apache License 2.0 as shown at http://www.apache.org/licenses/LICENSE-2.0. You may choose either license. // Code generated. DO NOT EDIT. // LogAnalytics API // // The LogAnalytics API for the LogAnalytics service. // package loganalytics // EmBridgeLifecycleStatesEnum Enum with underlying type: string type EmBridgeLifecycleStatesEnum string // Set of constants representing the allowable values for EmBridgeLifecycleStatesEnum const ( EmBridgeLifecycleStatesCreating EmBridgeLifecycleStatesEnum = "CREATING" EmBridgeLifecycleStatesActive EmBridgeLifecycleStatesEnum = "ACTIVE" EmBridgeLifecycleStatesDeleted EmBridgeLifecycleStatesEnum = "DELETED" EmBridgeLifecycleStatesNeedsAttention EmBridgeLifecycleStatesEnum = "NEEDS_ATTENTION" ) var mappingEmBridgeLifecycleStates = map[string]EmBridgeLifecycleStatesEnum{ "CREATING": EmBridgeLifecycleStatesCreating, "ACTIVE": EmBridgeLifecycleStatesActive, "DELETED": EmBridgeLifecycleStatesDeleted, "NEEDS_ATTENTION": EmBridgeLifecycleStatesNeedsAttention, } // GetEmBridgeLifecycleStatesEnumValues Enumerates the set of values for EmBridgeLifecycleStatesEnum func GetEmBridgeLifecycleStatesEnumValues() []EmBridgeLifecycleStatesEnum { values := make([]EmBridgeLifecycleStatesEnum, 0) for _, v := range mappingEmBridgeLifecycleStates { values = append(values, v)<|fim▁hole|>}<|fim▁end|>
} return values
<|file_name|>errors.rs<|end_file_name|><|fim▁begin|>//! # Errors //! //! Rust doesn't have exceptions, so errors are expressed as a variant on //! the standard library [`Result`]() type that implements the [`Error`]() //! trait. //! The problem with the `Error` trait is that it can be cumbersome to implement //! manually, and leads to a lot of conversion boiletplate. //! Luckily we have crates like [`error-chain`]() that make it really easy to //! declare error types. use redis; use serde_json; error_chain! { foreign_links { redis::RedisError, RedisError; serde_json::Error, JsonError; } errors { NotAnId { description("the given value isn't a valid id") display("the given value isn't a valid id")<|fim▁hole|> description("the requested person doesn't exist") display("the requested person doesn't exist") } } } use iron::IronError; use iron::status::Status; impl From<Error> for IronError { fn from(err: Error) -> IronError { match err { e @ Error { kind: ErrorKind::PersonNotFound, state: _ } => IronError::new(e, Status::NotFound), e => IronError::new(e, Status::InternalServerError), } } }<|fim▁end|>
} PersonNotFound {
<|file_name|>directxtest_index_buffer.cpp<|end_file_name|><|fim▁begin|>/* * Copyright (c) 2016 by Alexander Schroeder */ #include <agge/graphics/render_context.hpp> #include "agge/graphics/index_buffer.hpp" #include "directxtest_test.hpp" using agge::graphics::index_buffer; using agge::graphics::index_type; namespace agge { namespace directx { class index_buffer_test : public agge::directx::directxtest_with_context <|fim▁hole|> }; TEST_F(index_buffer_test, create_and_destroy) { auto buffer = context->create_index_buffer( agge::graphics::index_type::UINT32, 100 * sizeof(uint32_t)); void *ptr = buffer->lock(); ASSERT_EQ(100 * sizeof(uint32_t), buffer->size()); memset(ptr, 0, buffer->size()); buffer->unlock(); } } }<|fim▁end|>
{
<|file_name|>diskstats_common.go<|end_file_name|><|fim▁begin|>// Copyright 2019 The Prometheus Authors // Licensed under the Apache License, Version 2.0 (the "License"); // you may not use this file except in compliance with the License. // You may obtain a copy of the License at // // http://www.apache.org/licenses/LICENSE-2.0 // // Unless required by applicable law or agreed to in writing, software // distributed under the License is distributed on an "AS IS" BASIS, // WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. // See the License for the specific language governing permissions and // limitations under the License. <|fim▁hole|> package collector import ( "github.com/prometheus/client_golang/prometheus" ) const ( diskSubsystem = "disk" ) var ( diskLabelNames = []string{"device"} readsCompletedDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "reads_completed_total"), "The total number of reads completed successfully.", diskLabelNames, nil, ) readBytesDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "read_bytes_total"), "The total number of bytes read successfully.", diskLabelNames, nil, ) writesCompletedDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "writes_completed_total"), "The total number of writes completed successfully.", diskLabelNames, nil, ) writtenBytesDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "written_bytes_total"), "The total number of bytes written successfully.", diskLabelNames, nil, ) ioTimeSecondsDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "io_time_seconds_total"), "Total seconds spent doing I/Os.", diskLabelNames, nil, ) readTimeSecondsDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "read_time_seconds_total"), "The total number of seconds spent by all reads.", diskLabelNames, nil, ) writeTimeSecondsDesc = prometheus.NewDesc( prometheus.BuildFQName(namespace, diskSubsystem, "write_time_seconds_total"), "This is the total number of seconds spent by all writes.", diskLabelNames, nil, ) )<|fim▁end|>
// +build !nodiskstats // +build openbsd linux darwin
<|file_name|>block.go<|end_file_name|><|fim▁begin|>/* Copyright IBM Corp. 2016 All Rights Reserved. Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License. */ package common import ( "github.com/golang/protobuf/proto" "github.com/hyperledger/fabric/core/util" ) func (b *BlockHeader) Hash() []byte { data, err := proto.Marshal(b) // XXX this is wrong, protobuf is not the right mechanism to serialize for a hash if err != nil { panic("This should never fail and is generally irrecoverable") } return util.ComputeCryptoHash(data) }<|fim▁hole|> data, err := proto.Marshal(b) // XXX this is wrong, protobuf is not the right mechanism to serialize for a hash, AND, it is not a MerkleTree hash if err != nil { panic("This should never fail and is generally irrecoverable") } return util.ComputeCryptoHash(data) }<|fim▁end|>
func (b *BlockData) Hash() []byte {
<|file_name|>f5trafficshield.py<|end_file_name|><|fim▁begin|>#!/usr/bin/env python NAME = 'F5 Trafficshield' def is_waf(self): for hv in [['cookie', '^ASINFO='], ['server', 'F5-TrafficShield']]: r = self.matchheader(hv) if r is None: return elif r:<|fim▁hole|> return False<|fim▁end|>
return r # the following based on nmap's http-waf-fingerprint.nse if self.matchheader(('server', 'F5-TrafficShield')): return True
<|file_name|>CustomDataIndicatorExtensionsAlgorithm.py<|end_file_name|><|fim▁begin|># QUANTCONNECT.COM - Democratizing Finance, Empowering Individuals. # Lean Algorithmic Trading Engine v2.0. Copyright 2014 QuantConnect Corporation. # # Licensed under the Apache License, Version 2.0 (the "License"); # you may not use this file except in compliance with the License. # You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, # WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. # See the License for the specific language governing permissions and # limitations under the License. from clr import AddReference AddReference("System") AddReference("QuantConnect.Algorithm") AddReference("QuantConnect.Common") AddReference("QuantConnect.Indicators") from System import * from QuantConnect import * from QuantConnect.Indicators import * from QuantConnect.Data import * from QuantConnect.Data.Market import * from QuantConnect.Data.Custom import * from QuantConnect.Algorithm import * from QuantConnect.Python import PythonQuandl<|fim▁hole|>### </summary> ### <meta name="tag" content="using data" /> ### <meta name="tag" content="using quantconnect" /> ### <meta name="tag" content="custom data" /> ### <meta name="tag" content="indicators" /> ### <meta name="tag" content="indicator classes" /> ### <meta name="tag" content="plotting indicators" /> ### <meta name="tag" content="charting" /> class CustomDataIndicatorExtensionsAlgorithm(QCAlgorithm): # Initialize the data and resolution you require for your strategy def Initialize(self): self.SetStartDate(2014,1,1) self.SetEndDate(2018,1,1) self.SetCash(25000) self.vix = 'CBOE/VIX' self.vxv = 'CBOE/VXV' # Define the symbol and "type" of our generic data self.AddData(QuandlVix, self.vix, Resolution.Daily) self.AddData(Quandl, self.vxv, Resolution.Daily) # Set up default Indicators, these are just 'identities' of the closing price self.vix_sma = self.SMA(self.vix, 1, Resolution.Daily) self.vxv_sma = self.SMA(self.vxv, 1, Resolution.Daily) # This will create a new indicator whose value is smaVXV / smaVIX self.ratio = IndicatorExtensions.Over(self.vxv_sma, self.vix_sma) # Plot indicators each time they update using the PlotIndicator function self.PlotIndicator("Ratio", self.ratio) self.PlotIndicator("Data", self.vix_sma, self.vxv_sma) # OnData event is the primary entry point for your algorithm. Each new data point will be pumped in here. def OnData(self, data): # Wait for all indicators to fully initialize if not (self.vix_sma.IsReady and self.vxv_sma.IsReady and self.ratio.IsReady): return if not self.Portfolio.Invested and self.ratio.Current.Value > 1: self.MarketOrder(self.vix, 100) elif self.ratio.Current.Value < 1: self.Liquidate() # In CBOE/VIX data, there is a "vix close" column instead of "close" which is the # default column namein LEAN Quandl custom data implementation. # This class assigns new column name to match the the external datasource setting. class QuandlVix(PythonQuandl): def __init__(self): self.ValueColumnName = "VIX Close"<|fim▁end|>
### <summary> ### The algorithm creates new indicator value with the existing indicator method by Indicator Extensions ### Demonstration of using the external custom datasource Quandl to request the VIX and VXV daily data
<|file_name|>hello.rs<|end_file_name|><|fim▁begin|><|fim▁hole|><|fim▁end|>
println!("hello, world!");
<|file_name|>tlsconfig_test.go<|end_file_name|><|fim▁begin|>/* Copyright 2019 The Kubernetes Authors. Licensed under the Apache License, Version 2.0 (the "License"); you may not use this file except in compliance with the License. You may obtain a copy of the License at http://www.apache.org/licenses/LICENSE-2.0 Unless required by applicable law or agreed to in writing, software distributed under the License is distributed on an "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the License for the specific language governing permissions and limitations under the License. */ package dynamiccertificates import ( "reflect" "testing" "github.com/davecgh/go-spew/spew" ) var serverKey = []byte(`-----BEGIN RSA PRIVATE KEY----- MIIEowIBAAKCAQEA13f50PPWuR/InxLIoJjHdNSG+jVUd25CY7ZL2J023X2BAY+1 M6jkLR6C2nSFZnn58ubiB74/d1g/Fg1Twd419iR615A013f+qOoyFx3LFHxU1S6e v22fgJ6ntK/+4QD5MwNgOwD8k1jN2WxHqNWn16IF4Tidbv8M9A35YHAdtYDYaOJC kzjVztzRw1y6bKRakpMXxHylQyWmAKDJ2GSbRTbGtjr7Ji54WBfG43k94tO5X8K4 VGbz/uxrKe1IFMHNOlrjR438dbOXusksx9EIqDA9a42J3qjr5NKSqzCIbgBFl6qu 45V3A7cdRI/sJ2G1aqlWIXh2fAQiaFQAEBrPfwIDAQABAoIBAAZbxgWCjJ2d8H+x QDZtC8XI18redAWqPU9P++ECkrHqmDoBkalanJEwS1BDDATAKL4gTh9IX/sXoZT3 A7e+5PzEitN9r/GD2wIFF0FTYcDTAnXgEFM52vEivXQ5lV3yd2gn+1kCaHG4typp ZZv34iIc5+uDjjHOWQWCvA86f8XxX5EfYH+GkjfixTtN2xhWWlfi9vzYeESS4Jbt tqfH0iEaZ1Bm/qvb8vFgKiuSTOoSpaf+ojAdtPtXDjf1bBtQQG+RSQkP59O/taLM FCVuRrU8EtdB0+9anwmAP+O2UqjL5izA578lQtdIh13jHtGEgOcnfGNUphK11y9r Mg5V28ECgYEA9fwI6Xy1Rb9b9irp4bU5Ec99QXa4x2bxld5cDdNOZWJQu9OnaIbg kw/1SyUkZZCGMmibM/BiWGKWoDf8E+rn/ujGOtd70sR9U0A94XMPqEv7iHxhpZmD rZuSz4/snYbOWCZQYXFoD/nqOwE7Atnz7yh+Jti0qxBQ9bmkb9o0QW8CgYEA4D3d okzodg5QQ1y9L0J6jIC6YysoDedveYZMd4Un9bKlZEJev4OwiT4xXmSGBYq/7dzo OJOvN6qgPfibr27mSB8NkAk6jL/VdJf3thWxNYmjF4E3paLJ24X31aSipN1Ta6K3 KKQUQRvixVoI1q+8WHAubBDEqvFnNYRHD+AjKvECgYBkekjhpvEcxme4DBtw+OeQ 4OJXJTmhKemwwB12AERboWc88d3GEqIVMEWQJmHRotFOMfCDrMNfOxYv5+5t7FxL gaXHT1Hi7CQNJ4afWrKgmjjqrXPtguGIvq2fXzjVt8T9uNjIlNxe+kS1SXFjXsgH ftDY6VgTMB0B4ozKq6UAvQKBgQDER8K5buJHe+3rmMCMHn+Qfpkndr4ftYXQ9Kn4 MFiy6sV0hdfTgRzEdOjXu9vH/BRVy3iFFVhYvIR42iTEIal2VaAUhM94Je5cmSyd eE1eFHTqfRPNazmPaqttmSc4cfa0D4CNFVoZR6RupIl6Cect7jvkIaVUD+wMXxWo osOFsQKBgDLwVhZWoQ13RV/jfQxS3veBUnHJwQJ7gKlL1XZ16mpfEOOVnJF7Es8j TIIXXYhgSy/XshUbsgXQ+YGliye/rXSCTXHBXvWShOqxEMgeMYMRkcm8ZLp/DH7C kC2pemkLPUJqgSh1PASGcJbDJIvFGUfP69tUCYpHpk3nHzexuAg3 -----END RSA PRIVATE KEY-----`) var serverCert = []byte(`-----BEGIN CERTIFICATE----- MIIDQDCCAiigAwIBAgIJANWw74P5KJk2MA0GCSqGSIb3DQEBCwUAMDQxMjAwBgNV BAMMKWdlbmVyaWNfd2ViaG9va19hZG1pc3Npb25fcGx1Z2luX3Rlc3RzX2NhMCAX DTE3MTExNjAwMDUzOVoYDzIyOTEwOTAxMDAwNTM5WjAjMSEwHwYDVQQDExh3ZWJo b29rLXRlc3QuZGVmYXVsdC5zdmMwggEiMA0GCSqGSIb3DQEBAQUAA4IBDwAwggEK AoIBAQDXd/nQ89a5H8ifEsigmMd01Ib6NVR3bkJjtkvYnTbdfYEBj7UzqOQtHoLa dIVmefny5uIHvj93WD8WDVPB3jX2JHrXkDTXd/6o6jIXHcsUfFTVLp6/bZ+Anqe0<|fim▁hole|>r/7hAPkzA2A7APyTWM3ZbEeo1afXogXhOJ1u/wz0DflgcB21gNho4kKTONXO3NHD XLpspFqSkxfEfKVDJaYAoMnYZJtFNsa2OvsmLnhYF8bjeT3i07lfwrhUZvP+7Gsp 7UgUwc06WuNHjfx1s5e6ySzH0QioMD1rjYneqOvk0pKrMIhuAEWXqq7jlXcDtx1E j+wnYbVqqVYheHZ8BCJoVAAQGs9/AgMBAAGjZDBiMAkGA1UdEwQCMAAwCwYDVR0P BAQDAgXgMB0GA1UdJQQWMBQGCCsGAQUFBwMCBggrBgEFBQcDATApBgNVHREEIjAg hwR/AAABghh3ZWJob29rLXRlc3QuZGVmYXVsdC5zdmMwDQYJKoZIhvcNAQELBQAD ggEBAD/GKSPNyQuAOw/jsYZesb+RMedbkzs18sSwlxAJQMUrrXwlVdHrA8q5WhE6 ABLqU1b8lQ8AWun07R8k5tqTmNvCARrAPRUqls/ryER+3Y9YEcxEaTc3jKNZFLbc T6YtcnkdhxsiO136wtiuatpYL91RgCmuSpR8+7jEHhuFU01iaASu7ypFrUzrKHTF bKwiLRQi1cMzVcLErq5CDEKiKhUkoDucyARFszrGt9vNIl/YCcBOkcNvM3c05Hn3 M++C29JwS3Hwbubg6WO3wjFjoEhpCwU6qRYUz3MRp4tHO4kxKXx+oQnUiFnR7vW0 YkNtGc1RUDHwecCTFpJtPb7Yu/E= -----END CERTIFICATE-----`) func TestNewStaticCertKeyContent(t *testing.T) { testCertProvider, err := NewStaticSNICertKeyContent("test-cert", serverCert, serverKey, "foo") if err != nil { t.Error(err) } tests := []struct { name string clientCA CAContentProvider servingCert CertKeyContentProvider sniCerts []SNICertKeyContentProvider expected *dynamicCertificateContent expectedErr string }{ { name: "filled", clientCA: &staticCAContent{name: "test-ca", caBundle: &caBundleAndVerifier{caBundle: []byte("content-1")}}, servingCert: testCertProvider, sniCerts: []SNICertKeyContentProvider{testCertProvider}, expected: &dynamicCertificateContent{ clientCA: caBundleContent{caBundle: []byte("content-1")}, // ignore sni names for serving cert servingCert: certKeyContent{cert: serverCert, key: serverKey}, sniCerts: []sniCertKeyContent{{certKeyContent: certKeyContent{cert: serverCert, key: serverKey}, sniNames: []string{"foo"}}}, }, }, { name: "missingCA", clientCA: &staticCAContent{name: "test-ca", caBundle: &caBundleAndVerifier{caBundle: []byte("")}}, expected: nil, expectedErr: `not loading an empty client ca bundle from "test-ca"`, }, { name: "nil", expected: &dynamicCertificateContent{clientCA: caBundleContent{}, servingCert: certKeyContent{}}, }, } for _, test := range tests { t.Run(test.name, func(t *testing.T) { c := &DynamicServingCertificateController{ clientCA: test.clientCA, servingCert: test.servingCert, sniCerts: test.sniCerts, } actual, err := c.newTLSContent() if !reflect.DeepEqual(actual, test.expected) { t.Error(spew.Sdump(actual)) } switch { case err == nil && len(test.expectedErr) == 0: case err == nil && len(test.expectedErr) != 0: t.Errorf("missing %q", test.expectedErr) case err != nil && len(test.expectedErr) == 0: t.Error(err) case err != nil && err.Error() != test.expectedErr: t.Error(err) } }) } }<|fim▁end|>
<|file_name|>_tceparser.py<|end_file_name|><|fim▁begin|>""" Tensor Contraction Engine output parser. This module provides parsers of the output of the Tensor Contraction Engine of So Hirata into Tensor objects in drudge. """ import collections import itertools import re from sympy import nsimplify, sympify, Symbol from drudge import Term # # The driver function # ------------------- # def parse_tce_out(tce_out, range_cb, base_cb): """Parse a TCE output into a list of terms. A list of terms, and a dictionary of free symbols will be returned. """ lines = [] for line in tce_out.splitlines(): stripped = line.strip() if len(stripped) > 0: lines.append(stripped) continue free_vars = collections.defaultdict(set) return list(itertools.chain.from_iterable( _parse_tce_line(line, range_cb, base_cb, free_vars) for line in lines )), free_vars # # Internal functions # ------------------ # def _parse_tce_line(line, range_cb, base_cb, free_vars): """Parse a TCE output line into a list of terms. """ # Get the initial part in the bracket and the actual term specification # part after it. match_res = re.match( r'^\s*\[(?P<factors>.*)\](?P<term>[^\[\]]+)$', line ) if match_res is None:<|fim▁hole|> term_str = match_res.group('term').strip() # Get the actual term in its raw form. raw_term = _parse_term(term_str, range_cb, base_cb, free_vars) # Generates the actual list of terms based on the factors, possibly with # permutations. return _gen_terms(factors_str, raw_term) # # Some constants for the TCE output format # _SUM_BASE = 'Sum' # # Parsing the term specification # def _parse_term(term_str, range_cb, base_cb, free_vars): """Parse the term string after the square bracket into a Term. """ # First break the string into indexed values. summed_vars, idxed_vals = _break_into_idxed(term_str) sums = tuple((Symbol(i), range_cb(i)) for i in summed_vars) dumms = {i[0] for i in sums} amp = sympify('1') for base, indices in idxed_vals: indices_symbs = tuple(Symbol(i) for i in indices) for i, j in zip(indices_symbs, indices): if i not in dumms: free_vars[range_cb(j)].add(i) continue base_symb = base_cb(base, indices_symbs) amp *= base_symb[indices_symbs] continue return Term(sums=sums, amp=amp, vecs=()) def _break_into_idxed(term_str): """Break the term string into pairs of indexed base and indices. Both the base and the indices variables are going to be simple strings in the return value. """ # First break it into fields separated by the multiplication asterisk. fields = (i for i in re.split(r'\s*\*\s*', term_str) if len(i) > 0) # Parse the fields one-by-one. idxed_vals = [] for field in fields: # Break the field into the base part and the indices part. match_res = re.match( r'(?P<base>\w+)\s*\((?P<indices>.*)\)', field ) if match_res is None: raise ValueError('Invalid indexed value', field) # Generate the final result. idxed_vals.append(( match_res.group('base'), tuple(match_res.group('indices').split()) )) continue # Summation always comes first in TCE output. if idxed_vals[0][0] == _SUM_BASE: return idxed_vals[0][1], idxed_vals[1:] else: return (), idxed_vals # # Final term generation based on the raw term # ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^ # def _gen_terms(factors_str, raw_term): """Generate the actual terms based on the initial factor string. The raw term should be a term directly parsed from the term specification part of the TCE line. This function will use the factors string in the square bracket to turn it into a list of terms for the final value of the line. """ # The regular expression for a factor. factor_regex = r'\s*'.join([ r'(?P<sign>[+-])', r'(?P<factor_number>[0-9.]+)', r'(?:\*\s*P\((?P<perm_from>[^=>]*)=>(?P<perm_to>[^)]*)\))?', ]) + r'\s*' mismatch_regex = r'.' regex = '(?P<factor>{})|(?P<mismatch>{})'.format( factor_regex, mismatch_regex ) # Iterate over the factors. terms = [] for match_res in re.finditer(regex, factors_str): # Test if the result matches a factor. if match_res.group('factor') is None: raise ValueError('Invalid factor string', factors_str) # The value of the factor. factor_value = nsimplify(''.join( match_res.group('sign', 'factor_number') ), rational=True) # Get the substitution for the permutation of the indices. if match_res.group('perm_from') is not None: from_vars = match_res.group('perm_from').split() to_vars = match_res.group('perm_to').split() subs = { Symbol(from_var): Symbol(to_var) for from_var, to_var in zip(from_vars, to_vars) } else: subs = {} # Add the result. terms.append(raw_term.subst(subs).scale(factor_value)) # Continue to the next factor. continue return terms<|fim▁end|>
raise ValueError('Invalid TCE output line', line) factors_str = match_res.group('factors').strip()
<|file_name|>__init__.py<|end_file_name|><|fim▁begin|>__doc__ = """ Preprocess input data, include `video` format should be `avi` or `mp4` `slide` format should be `pdf` and auto-convert to `jpg` or a set of `jpg` images `summary` save `video` and `slide` infomation to summary store `reducer` reduce video frames to more distingushable one `reducer.probe` probing video to compute distingushable posibility position """ __all__ = ["probe"] import numpy as np from lib.exp.base import ExpCommon from probe import Probe class Const(object): __doc__ = "Constants for preprocessing data" Names = np.array( ["Avg 2", "Avg 10", "Avg 15", "Avg 20", "Avg 30", "Avg 60", "Avg 300", "Bkg Model"]) Rkeys = np.array( ["diff_next/size_2", "dn/size_10", "diff_next/size_15", "dn/size_20", "diff_next/size_30", "diff_next/size_60", "diff_next/size_300", "diff_bkg"]) Doffsets = np.array([1, 9, 14, 19, 29, 59, 299, 1]) class Reducer(ExpCommon): def __init__(self, root, name): ExpCommon.__init__(self, root, name) def __compress(self, data, keep_last=False): """ Get the compressed dataset and compressed ratio """ before = len(data) maxv = data.iloc[0].name prev = data.iloc[0].name for curv in data.index[1:]: if (curv - prev) == 1: # continuous sequence if data.ix[maxv]['diff'] < data.ix[curv]['diff']: # drop previous max if its diff smaller data = data.drop([maxv]) maxv = curv else: # drop continuous item data = data.drop([curv]) else: # seperate sequence start maxv = curv prev = curv return data, before, len(data) def __get_data(self, key): """ Get probed `differenc` values and `frame` data """ df = self.load(key) dmean = df["diff"].mean() can = df[df["diff"].gt(dmean)] return can, len(df) def __results(self, **opts): oo = opts["origin"] ff = opts["final"] info = "Original: {}, thresed: {}, final: {}, ratio: {}".\ format(oo, opts["thresed"], ff, ff*1.0/oo) istr = "Reduce data from {}".format(info) print istr self.elog.info(istr) self.save_rtlog(opts.keys(), opts.values()) def reduce(self, key, save=False): can, orl = self.__get_data(key) red, thresed, after = self.__compress(can) self.__results(key=key, origin=orl, thresed=thresed, final=after) if save: self.save("/nr/{}".format(key), red) return red def clear(self): self.delete_log() # self.delete_store() # be careful def frame_ids(self, ikey=4, delta=True): rk = "/nr/" + Const.Rkeys[ikey] dfv = self.load(rk).frame_id if delta: dfv -= 30 return dfv[dfv > 0].values.astype(np.int32) def probing(self, qs=2): pb = Probe(self.root, self.name) for frame_id, opt in pb.diff_next(qs=qs): self.elog.info("Qs: {}, FrameID: {}, time: {}". format(qs, frame_id, opt)) self.save("dn/size_{}".format(qs), pb.pdf)<|fim▁hole|> def batch_probing(self, qss=[2]): """ qss: query size list """ for qs in qss: self.probing(qs) def zipkey(self, keys=[]): if len(keys) == 0: keys = range(len(Const.Names)) inxs = range(len(keys)) iz = zip(inxs, Const.Names[keys], Const.Rkeys[keys], Const.Doffsets[keys]) return iz<|fim▁end|>
<|file_name|>contact-events.ts<|end_file_name|><|fim▁begin|>import { EventEmitter } from 'events' import type TypedEventEmitter from 'typed-emitter' import type { ContactInterface, FriendshipInterface, MessageInterface, } from '../user-modules/mod.js' type ContactEventListenerMessage = (this: ContactInterface, message: MessageInterface, date?: Date) => void | Promise<void> type ContactEventListenerFriendship = (friendship: FriendshipInterface) => void | Promise<void> interface ContactEventListeners { friendship : ContactEventListenerFriendship, message : ContactEventListenerMessage, } const ContactEventEmitter = EventEmitter as any as new () => TypedEventEmitter< ContactEventListeners<|fim▁hole|>> export type { ContactEventListeners, ContactEventListenerMessage, ContactEventListenerFriendship, } export { ContactEventEmitter, }<|fim▁end|>
<|file_name|>problem_38.py<|end_file_name|><|fim▁begin|>"""38. Count and Say https://leetcode.com/problems/count-and-say/description/ The count-and-say sequence is the sequence of integers with the first five terms as following: 1. 1 2. 11 3. 21 4. 1211 5. 111221 1 is read off as "one 1" or 11. 11 is read off as "two 1s" or 21. 21 is read off as "one 2, then one 1" or 1211. Given an integer n where 1 ≤ n ≤ 30, generate the n^th term of the count-and-say sequence. Note: Each term of the sequence of integers will be represented as a string. Example 1: <|fim▁hole|> Input: 4 Output: "1211" """ class Solution: def count_and_say(self, n: int) -> str: assert 1 <= n <= 30 if n == 1: return "1" def say(num_str: str) -> str: res = "" cur_digit = num_str[0] cur_digit_count = 1 for i in range(1, len(num_str)): if num_str[i] == cur_digit: cur_digit_count += 1 else: res += str(cur_digit_count) + cur_digit cur_digit = num_str[i] cur_digit_count = 1 res += str(cur_digit_count) + cur_digit return res ans = "1" for i in range(1, n): ans = say(ans) return ans<|fim▁end|>
Input: 1 Output: "1" Example 2:
<|file_name|>ordering.py<|end_file_name|><|fim▁begin|># -*- coding: utf-8 -*- '''auto ordering call chain test mixins''' from inspect import ismodule from twoq.support import port class ARandomQMixin(object): def test_choice(self): self.assertEqual(len(list(self.qclass(1, 2, 3, 4, 5, 6).choice())), 1) def test_sample(self): self.assertEqual(len(self.qclass(1, 2, 3, 4, 5, 6).sample(3).end()), 3) def test_shuffle(self): self.assertEqual( len(self.qclass(1, 2, 3, 4, 5, 6).shuffle()), len([5, 4, 6, 3, 1, 2]), ) class ACombineQMixin(object): # def test_combinations(self): # foo = self.qclass('ABCD').combinations(2).value(), # self.assertEqual( # foo[0], # [('A', 'B'), ('A', 'C'), ('A', 'D'), ('B', 'C'), ('B', 'D'), # ('C', 'D')], # foo, # ) # # def test_permutations(self): # foo = self.qclass('ABCD').permutations(2).value() # self.assertEqual( # foo[0], # [('A', 'B'), ('A', 'C'), ('A', 'D'), ('B', 'A'), ('B', 'C'), # ('B', 'D'), ('C', 'A'), ('C', 'B'), ('C', 'D'), ('D', 'A'), # ('D', 'B'), ('D', 'C')], # foo,<|fim▁hole|> def test_product(self): foo = self.qclass('ABCD', 'xy').product().value() self.assertEqual( foo, [('A', 'x'), ('A', 'y'), ('B', 'x'), ('B', 'y'), ('C', 'x'), ('C', 'y'), ('D', 'x'), ('D', 'y')], foo, ) class AOrderQMixin(ARandomQMixin, ACombineQMixin): '''combination mixin''' def test_group(self,): from math import floor self.assertEqual( self.qclass(1.3, 2.1, 2.4).tap(lambda x: floor(x)).group().end(), [[1.0, [1.3]], [2.0, [2.1, 2.4]]] ) self.assertEqual( self.qclass(1.3, 2.1, 2.4).group().end(), [[1.3, [1.3]], [2.1, [2.1]], [2.4, [2.4]]], ) def test_grouper(self): self.assertEqual( self.qclass( 'moe', 'larry', 'curly', 30, 40, 50, True ).grouper(2, 'x').end(), [('moe', 'larry'), ('curly', 30), (40, 50), (True, 'x')] ) def test_reversed(self): self.assertEqual( self.qclass(5, 4, 3, 2, 1).reverse().end(), [1, 2, 3, 4, 5], ) def test_sort(self): from math import sin self.assertEqual( self.qclass(1, 2, 3, 4, 5, 6).tap( lambda x: sin(x) ).sort().end(), [5, 4, 6, 3, 1, 2], ) self.assertEqual( self.qclass(4, 6, 65, 3, 63, 2, 4).sort().end(), [2, 3, 4, 4, 6, 63, 65], ) __all__ = sorted(name for name, obj in port.items(locals()) if not any([ name.startswith('_'), ismodule(obj), name in ['ismodule', 'port'] ])) del ismodule<|fim▁end|>
# )
<|file_name|>sensorimotor_experiment_runner.py<|end_file_name|><|fim▁begin|># ---------------------------------------------------------------------- # Numenta Platform for Intelligent Computing (NuPIC) # Copyright (C) 2014, Numenta, Inc. Unless you have an agreement # with Numenta, Inc., for a separate license for this software code, the # following terms and conditions apply: # # This program is free software: you can redistribute it and/or modify # it under the terms of the GNU General Public License version 3 as # published by the Free Software Foundation. # # This program is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. # See the GNU General Public License for more details. # # You should have received a copy of the GNU General Public License # along with this program. If not, see http://www.gnu.org/licenses. # # http://numenta.org/licenses/ # ---------------------------------------------------------------------- import time import numpy from nupic.bindings.math import GetNTAReal from nupic.research.monitor_mixin.monitor_mixin_base import MonitorMixinBase from nupic.research.monitor_mixin.temporal_memory_monitor_mixin import ( TemporalMemoryMonitorMixin) from sensorimotor.fast_general_temporal_memory import ( FastGeneralTemporalMemory as GeneralTemporalMemory) # Uncomment the line below to use GeneralTemporalMemory # from sensorimotor.general_temporal_memory import GeneralTemporalMemory from sensorimotor.temporal_pooler import TemporalPooler # Uncomment the line below to use SpatialTemporalPooler # from sensorimotor.spatial_temporal_pooler import SpatialTemporalPooler as TemporalPooler from sensorimotor.temporal_pooler_monitor_mixin import ( TemporalPoolerMonitorMixin) class MonitoredGeneralTemporalMemory(TemporalMemoryMonitorMixin, GeneralTemporalMemory): pass class MonitoredTemporalPooler(TemporalPoolerMonitorMixin, TemporalPooler): pass """ Experiment runner class for running networks with layer 4 and layer 3. The client is responsible for setting up universes, agents, and worlds. This class just sets up and runs the HTM learning algorithms. """ realDType = GetNTAReal() class SensorimotorExperimentRunner(object): DEFAULT_TM_PARAMS = { # These should be decent for most experiments, shouldn't need to override # these too often. Might want to increase cellsPerColumn for capacity # experiments. "cellsPerColumn": 8, "initialPermanence": 0.5, "connectedPermanence": 0.6, "permanenceIncrement": 0.1, "permanenceDecrement": 0.02, # We will force client to override these "columnDimensions": "Sorry", "minThreshold": "Sorry", "maxNewSynapseCount": "Sorry", "activationThreshold": "Sorry", } DEFAULT_TP_PARAMS = { # Need to check these parameters and find stable values that will be # consistent across most experiments. "synPermInactiveDec": 0, # TODO: Check we can use class default here. "synPermActiveInc": 0.001, # TODO: Check we can use class default here. "synPredictedInc": 0.5, # TODO: Why so high?? "potentialPct": 0.9, # TODO: need to check impact of this for pooling "initConnectedPct": 0.5, # TODO: need to check impact of this for pooling "poolingThreshUnpredicted": 0.0, # We will force client to override these "numActiveColumnsPerInhArea": "Sorry", } def __init__(self, tmOverrides=None, tpOverrides=None, seed=42): # Initialize Layer 4 temporal memory params = dict(self.DEFAULT_TM_PARAMS) params.update(tmOverrides or {}) params["seed"] = seed self._checkParams(params) self.tm = MonitoredGeneralTemporalMemory(mmName="TM", **params) # Initialize Layer 3 temporal pooler params = dict(self.DEFAULT_TP_PARAMS) params["inputDimensions"] = [self.tm.numberOfCells()] params["potentialRadius"] = self.tm.numberOfCells() params["seed"] = seed params.update(tpOverrides or {}) self._checkParams(params) self.tp = MonitoredTemporalPooler(mmName="TP", **params) <|fim▁hole|> raise RuntimeError("Param "+k+" must be specified") def feedTransition(self, sensorPattern, motorPattern, sensorimotorPattern, tmLearn=True, tpLearn=None, sequenceLabel=None): if sensorPattern is None: self.tm.reset() self.tp.reset() else: # Feed the TM self.tm.compute(sensorPattern, activeExternalCells=motorPattern, formInternalConnections=True, learn=tmLearn, sequenceLabel=sequenceLabel) # If requested, feed the TP if tpLearn is not None: tpInputVector, burstingColumns, correctlyPredictedCells = ( self.formatInputForTP()) activeArray = numpy.zeros(self.tp.getNumColumns()) self.tp.compute(tpInputVector, tpLearn, activeArray, burstingColumns, correctlyPredictedCells, sequenceLabel=sequenceLabel) def feedLayers(self, sequences, tmLearn=True, tpLearn=None, verbosity=0, showProgressInterval=None): """ Feed the given sequences to the HTM algorithms. @param tmLearn: (bool) Either False, or True @param tpLearn: (None,bool) Either None, False, or True. If None, temporal pooler will be skipped. @param showProgressInterval: (int) Prints progress every N iterations, where N is the value of this param """ (sensorSequence, motorSequence, sensorimotorSequence, sequenceLabels) = sequences currentTime = time.time() for i in xrange(len(sensorSequence)): sensorPattern = sensorSequence[i] motorPattern = motorSequence[i] sensorimotorPattern = sensorimotorSequence[i] sequenceLabel = sequenceLabels[i] self.feedTransition(sensorPattern, motorPattern, sensorimotorPattern, tmLearn=tmLearn, tpLearn=tpLearn, sequenceLabel=sequenceLabel) if (showProgressInterval is not None and i > 0 and i % showProgressInterval == 0): print ("Fed {0} / {1} elements of the sequence " "in {2:0.2f} seconds.".format( i, len(sensorSequence), time.time() - currentTime)) currentTime = time.time() if verbosity >= 2: # Print default TM traces traces = self.tm.mmGetDefaultTraces(verbosity=verbosity) print MonitorMixinBase.mmPrettyPrintTraces(traces, breakOnResets= self.tm.mmGetTraceResets()) if tpLearn is not None: # Print default TP traces traces = self.tp.mmGetDefaultTraces(verbosity=verbosity) print MonitorMixinBase.mmPrettyPrintTraces(traces, breakOnResets= self.tp.mmGetTraceResets()) print @staticmethod def generateSequences(length, agents, numSequences=1, verbosity=0): """ @param length (int) Length of each sequence to generate, one for each agent @param agents (AbstractAgent) Agents acting in their worlds @return (tuple) (sensor sequence, motor sequence, sensorimotor sequence, sequence labels) """ sensorSequence = [] motorSequence = [] sensorimotorSequence = [] sequenceLabels = [] for _ in xrange(numSequences): for agent in agents: s,m,sm = agent.generateSensorimotorSequence(length, verbosity=verbosity) sensorSequence += s motorSequence += m sensorimotorSequence += sm sequenceLabels += [agent.world.toString()] * length sensorSequence.append(None) motorSequence.append(None) sensorimotorSequence.append(None) sequenceLabels.append(None) return sensorSequence, motorSequence, sensorimotorSequence, sequenceLabels def formatInputForTP(self): """ Given an instance of the TM, format the information we need to send to the TP. """ # all currently active cells in layer 4 tpInputVector = numpy.zeros( self.tm.numberOfCells()).astype(realDType) tpInputVector[list(self.tm.activeCellsIndices())] = 1 # bursting columns in layer 4 burstingColumns = numpy.zeros( self.tm.numberOfColumns()).astype(realDType) burstingColumns[list(self.tm.unpredictedActiveColumns)] = 1 # correctly predicted cells in layer 4 correctlyPredictedCells = numpy.zeros( self.tm.numberOfCells()).astype(realDType) correctlyPredictedCells[list(self.tm.predictedActiveCellsIndices())] = 1 return tpInputVector, burstingColumns, correctlyPredictedCells def formatRow(self, x, formatString = "%d", rowSize = 700): """ Utility routine for pretty printing large vectors """ s = '' for c,v in enumerate(x): if c > 0 and c % 7 == 0: s += ' ' if c > 0 and c % rowSize == 0: s += '\n' s += formatString % v s += ' ' return s<|fim▁end|>
def _checkParams(self, params): for k,v in params.iteritems(): if v == "Sorry":
<|file_name|>chevronButton.styles.ts<|end_file_name|><|fim▁begin|>/** * Copyright (C) 2021 3D Repo Ltd * * This program is free software: you can redistribute it and/or modify * it under the terms of the GNU Affero General Public License as * published by the Free Software Foundation, either version 3 of the * License, or (at your option) any later version. * * This program is distributed in the hope that it will be useful, * but WITHOUT ANY WARRANTY; without even the implied warranty of * MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the * GNU Affero General Public License for more details. * * You should have received a copy of the GNU Affero General Public License * along with this program. If not, see <http://www.gnu.org/licenses/>. */ import { IconButton } from '@material-ui/core'; import styled, { css } from 'styled-components'; export const StyledIconButton = styled(IconButton)` height: 28px; width: 28px; padding: 0; margin: 0 10px 0 0; display: flex; align-items: center; svg { height: 7px; width: 100%; margin-top: 2px; } ${({ $isOn }) => $isOn && css` background-color: ${({ theme }) => theme.palette.secondary.main}; svg { margin-bottom: 3px; transform: rotate(180deg); path { fill: ${({ theme }) => theme.palette.primary.contrast}; } } `} ${({ $isLoading }) => $isLoading && css` pointer-events: none; `} border: 1px solid ${({ theme }) => theme.palette.secondary.main}; &:hover { border-style: none; background-color: ${({ theme }) => theme.palette.base.lightest}; svg { path { fill: ${({ theme }) => theme.palette.secondary.main}; } } } &:active { background-color: ${({ theme }) => theme.palette.secondary.light}; } &.Mui-focusVisible { background-color: ${({ theme }) => theme.palette.primary.contrast}; border-style: solid; } :disabled { background-color: transparent; svg { path { fill: ${({ theme }) => theme.palette.base.light}; } } }<|fim▁hole|><|fim▁end|>
`;
<|file_name|>matrix.cc<|end_file_name|><|fim▁begin|>#include <cstdio> #include <cmath> #include "matrix.h" #include "vector.h" #include "quat.h" using namespace std; // ----------- Matrix3x3 -------------- Matrix3x3 Matrix3x3::identity = Matrix3x3(1, 0, 0, 0, 1, 0, 0, 0, 1); Matrix3x3::Matrix3x3() { *this = identity; } Matrix3x3::Matrix3x3( scalar_t m11, scalar_t m12, scalar_t m13, scalar_t m21, scalar_t m22, scalar_t m23, scalar_t m31, scalar_t m32, scalar_t m33) { m[0][0] = m11; m[0][1] = m12; m[0][2] = m13; m[1][0] = m21; m[1][1] = m22; m[1][2] = m23; m[2][0] = m31; m[2][1] = m32; m[2][2] = m33; } Matrix3x3::Matrix3x3(const Vector3 &ivec, const Vector3 &jvec, const Vector3 &kvec) { set_row_vector(ivec, 0); set_row_vector(jvec, 1); set_row_vector(kvec, 2); } Matrix3x3::Matrix3x3(const mat3_t cmat) { memcpy(m, cmat, sizeof(mat3_t)); } Matrix3x3::Matrix3x3(const Matrix4x4 &mat4x4) { for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { m[i][j] = mat4x4[i][j]; } } } Matrix3x3 operator +(const Matrix3x3 &m1, const Matrix3x3 &m2) { Matrix3x3 res; const scalar_t *op1 = m1.m[0], *op2 = m2.m[0]; scalar_t *dest = res.m[0]; for(int i=0; i<9; i++) { *dest++ = *op1++ + *op2++; } return res; } Matrix3x3 operator -(const Matrix3x3 &m1, const Matrix3x3 &m2) { Matrix3x3 res; const scalar_t *op1 = m1.m[0], *op2 = m2.m[0]; scalar_t *dest = res.m[0]; for(int i=0; i<9; i++) { *dest++ = *op1++ - *op2++; } return res; } Matrix3x3 operator *(const Matrix3x3 &m1, const Matrix3x3 &m2) { Matrix3x3 res; for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { res.m[i][j] = m1.m[i][0] * m2.m[0][j] + m1.m[i][1] * m2.m[1][j] + m1.m[i][2] * m2.m[2][j]; } } return res; } void operator +=(Matrix3x3 &m1, const Matrix3x3 &m2) { scalar_t *op1 = m1.m[0]; const scalar_t *op2 = m2.m[0]; for(int i=0; i<9; i++) { *op1++ += *op2++; } } void operator -=(Matrix3x3 &m1, const Matrix3x3 &m2) { scalar_t *op1 = m1.m[0]; const scalar_t *op2 = m2.m[0]; for(int i=0; i<9; i++) { *op1++ -= *op2++; } } void operator *=(Matrix3x3 &m1, const Matrix3x3 &m2) { Matrix3x3 res; for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { res.m[i][j] = m1.m[i][0] * m2.m[0][j] + m1.m[i][1] * m2.m[1][j] + m1.m[i][2] * m2.m[2][j]; } } memcpy(m1.m, res.m, 9 * sizeof(scalar_t)); } Matrix3x3 operator *(const Matrix3x3 &mat, scalar_t scalar) { Matrix3x3 res; const scalar_t *mptr = mat.m[0]; scalar_t *dptr = res.m[0]; for(int i=0; i<9; i++) { *dptr++ = *mptr++ * scalar; } return res; } Matrix3x3 operator *(scalar_t scalar, const Matrix3x3 &mat) { Matrix3x3 res; const scalar_t *mptr = mat.m[0]; scalar_t *dptr = res.m[0]; for(int i=0; i<9; i++) { *dptr++ = *mptr++ * scalar; } return res; } void operator *=(Matrix3x3 &mat, scalar_t scalar) { scalar_t *mptr = mat.m[0]; for(int i=0; i<9; i++) { *mptr++ *= scalar; } } void Matrix3x3::translate(const Vector2 &trans) { Matrix3x3 tmat(1, 0, trans.x, 0, 1, trans.y, 0, 0, 1); *this *= tmat; } void Matrix3x3::set_translation(const Vector2 &trans) { *this = Matrix3x3(1, 0, trans.x, 0, 1, trans.y, 0, 0, 1); } void Matrix3x3::rotate(scalar_t angle) { scalar_t cos_a = cos(angle); scalar_t sin_a = sin(angle); Matrix3x3 rmat( cos_a, -sin_a, 0, sin_a, cos_a, 0, 0, 0, 1); *this *= rmat; } void Matrix3x3::set_rotation(scalar_t angle) { scalar_t cos_a = cos(angle); scalar_t sin_a = sin(angle); *this = Matrix3x3(cos_a, -sin_a, 0, sin_a, cos_a, 0, 0, 0, 1); } void Matrix3x3::rotate(const Vector3 &euler_angles) { Matrix3x3 xrot, yrot, zrot; xrot = Matrix3x3( 1, 0, 0, 0, cos(euler_angles.x), -sin(euler_angles.x), 0, sin(euler_angles.x), cos(euler_angles.x)); yrot = Matrix3x3( cos(euler_angles.y), 0, sin(euler_angles.y), 0, 1, 0, -sin(euler_angles.y), 0, cos(euler_angles.y)); zrot = Matrix3x3( cos(euler_angles.z), -sin(euler_angles.z), 0, sin(euler_angles.z), cos(euler_angles.z), 0, 0, 0, 1); *this *= xrot * yrot * zrot; } void Matrix3x3::set_rotation(const Vector3 &euler_angles) { Matrix3x3 xrot, yrot, zrot; xrot = Matrix3x3( 1, 0, 0, 0, cos(euler_angles.x), -sin(euler_angles.x), 0, sin(euler_angles.x), cos(euler_angles.x)); yrot = Matrix3x3( cos(euler_angles.y), 0, sin(euler_angles.y), 0, 1, 0, -sin(euler_angles.y), 0, cos(euler_angles.y)); zrot = Matrix3x3( cos(euler_angles.z), -sin(euler_angles.z), 0, sin(euler_angles.z), cos(euler_angles.z), 0, 0, 0, 1); *this = xrot * yrot * zrot; } void Matrix3x3::rotate(const Vector3 &axis, scalar_t angle)<|fim▁hole|> scalar_t nxsq = axis.x * axis.x; scalar_t nysq = axis.y * axis.y; scalar_t nzsq = axis.z * axis.z; Matrix3x3 xform; xform.m[0][0] = nxsq + (1-nxsq) * cosa; xform.m[0][1] = axis.x * axis.y * invcosa - axis.z * sina; xform.m[0][2] = axis.x * axis.z * invcosa + axis.y * sina; xform.m[1][0] = axis.x * axis.y * invcosa + axis.z * sina; xform.m[1][1] = nysq + (1-nysq) * cosa; xform.m[1][2] = axis.y * axis.z * invcosa - axis.x * sina; xform.m[2][0] = axis.x * axis.z * invcosa - axis.y * sina; xform.m[2][1] = axis.y * axis.z * invcosa + axis.x * sina; xform.m[2][2] = nzsq + (1-nzsq) * cosa; *this *= xform; } void Matrix3x3::set_rotation(const Vector3 &axis, scalar_t angle) { scalar_t sina = (scalar_t)sin(angle); scalar_t cosa = (scalar_t)cos(angle); scalar_t invcosa = 1-cosa; scalar_t nxsq = axis.x * axis.x; scalar_t nysq = axis.y * axis.y; scalar_t nzsq = axis.z * axis.z; reset_identity(); m[0][0] = nxsq + (1-nxsq) * cosa; m[0][1] = axis.x * axis.y * invcosa - axis.z * sina; m[0][2] = axis.x * axis.z * invcosa + axis.y * sina; m[1][0] = axis.x * axis.y * invcosa + axis.z * sina; m[1][1] = nysq + (1-nysq) * cosa; m[1][2] = axis.y * axis.z * invcosa - axis.x * sina; m[2][0] = axis.x * axis.z * invcosa - axis.y * sina; m[2][1] = axis.y * axis.z * invcosa + axis.x * sina; m[2][2] = nzsq + (1-nzsq) * cosa; } void Matrix3x3::scale(const Vector3 &scale_vec) { Matrix3x3 smat( scale_vec.x, 0, 0, 0, scale_vec.y, 0, 0, 0, scale_vec.z); *this *= smat; } void Matrix3x3::set_scaling(const Vector3 &scale_vec) { *this = Matrix3x3( scale_vec.x, 0, 0, 0, scale_vec.y, 0, 0, 0, scale_vec.z); } void Matrix3x3::set_column_vector(const Vector3 &vec, unsigned int col_index) { m[0][col_index] = vec.x; m[1][col_index] = vec.y; m[2][col_index] = vec.z; } void Matrix3x3::set_row_vector(const Vector3 &vec, unsigned int row_index) { m[row_index][0] = vec.x; m[row_index][1] = vec.y; m[row_index][2] = vec.z; } Vector3 Matrix3x3::get_column_vector(unsigned int col_index) const { return Vector3(m[0][col_index], m[1][col_index], m[2][col_index]); } Vector3 Matrix3x3::get_row_vector(unsigned int row_index) const { return Vector3(m[row_index][0], m[row_index][1], m[row_index][2]); } void Matrix3x3::transpose() { Matrix3x3 tmp = *this; for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { m[i][j] = tmp[j][i]; } } } Matrix3x3 Matrix3x3::transposed() const { Matrix3x3 res; for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { res[i][j] = m[j][i]; } } return res; } scalar_t Matrix3x3::determinant() const { return m[0][0] * (m[1][1]*m[2][2] - m[1][2]*m[2][1]) - m[0][1] * (m[1][0]*m[2][2] - m[1][2]*m[2][0]) + m[0][2] * (m[1][0]*m[2][1] - m[1][1]*m[2][0]); } Matrix3x3 Matrix3x3::inverse() const { // TODO: implement 3x3 inverse return *this; } ostream &operator <<(ostream &out, const Matrix3x3 &mat) { for(int i=0; i<3; i++) { char str[100]; sprintf(str, "[ %12.5f %12.5f %12.5f ]\n", (float)mat.m[i][0], (float)mat.m[i][1], (float)mat.m[i][2]); out << str; } return out; } /* ----------------- Matrix4x4 implementation --------------- */ Matrix4x4 Matrix4x4::identity = Matrix4x4(1, 0, 0, 0, 0, 1, 0, 0, 0, 0, 1, 0, 0, 0, 0, 1); Matrix4x4::Matrix4x4() { *this = identity; } Matrix4x4::Matrix4x4( scalar_t m11, scalar_t m12, scalar_t m13, scalar_t m14, scalar_t m21, scalar_t m22, scalar_t m23, scalar_t m24, scalar_t m31, scalar_t m32, scalar_t m33, scalar_t m34, scalar_t m41, scalar_t m42, scalar_t m43, scalar_t m44) { m[0][0] = m11; m[0][1] = m12; m[0][2] = m13; m[0][3] = m14; m[1][0] = m21; m[1][1] = m22; m[1][2] = m23; m[1][3] = m24; m[2][0] = m31; m[2][1] = m32; m[2][2] = m33; m[2][3] = m34; m[3][0] = m41; m[3][1] = m42; m[3][2] = m43; m[3][3] = m44; } Matrix4x4::Matrix4x4(const mat4_t cmat) { memcpy(m, cmat, sizeof(mat4_t)); } Matrix4x4::Matrix4x4(const Matrix3x3 &mat3x3) { reset_identity(); for(int i=0; i<3; i++) { for(int j=0; j<3; j++) { m[i][j] = mat3x3[i][j]; } } } Matrix4x4 operator +(const Matrix4x4 &m1, const Matrix4x4 &m2) { Matrix4x4 res; const scalar_t *op1 = m1.m[0], *op2 = m2.m[0]; scalar_t *dest = res.m[0]; for(int i=0; i<16; i++) { *dest++ = *op1++ + *op2++; } return res; } Matrix4x4 operator -(const Matrix4x4 &m1, const Matrix4x4 &m2) { Matrix4x4 res; const scalar_t *op1 = m1.m[0], *op2 = m2.m[0]; scalar_t *dest = res.m[0]; for(int i=0; i<16; i++) { *dest++ = *op1++ - *op2++; } return res; } /* Matrix4x4 operator *(const Matrix4x4 &m1, const Matrix4x4 &m2) { Matrix4x4 res; for(int i=0; i<4; i++) { for(int j=0; j<4; j++) { res.m[i][j] = m1.m[i][0] * m2.m[0][j] + m1.m[i][1] * m2.m[1][j] + m1.m[i][2] * m2.m[2][j] + m1.m[i][3] * m2.m[3][j]; } } return res; } */ void operator +=(Matrix4x4 &m1, const Matrix4x4 &m2) { scalar_t *op1 = m1.m[0]; const scalar_t *op2 = m2.m[0]; for(int i=0; i<16; i++) { *op1++ += *op2++; } } void operator -=(Matrix4x4 &m1, const Matrix4x4 &m2) { scalar_t *op1 = m1.m[0]; const scalar_t *op2 = m2.m[0]; for(int i=0; i<16; i++) { *op1++ -= *op2++; } } void operator *=(Matrix4x4 &m1, const Matrix4x4 &m2) { Matrix4x4 res; for(int i=0; i<4; i++) { for(int j=0; j<4; j++) { res.m[i][j] = m1.m[i][0] * m2.m[0][j] + m1.m[i][1] * m2.m[1][j] + m1.m[i][2] * m2.m[2][j] + m1.m[i][3] * m2.m[3][j]; } } memcpy(m1.m, res.m, 16 * sizeof(scalar_t)); } Matrix4x4 operator *(const Matrix4x4 &mat, scalar_t scalar) { Matrix4x4 res; const scalar_t *mptr = mat.m[0]; scalar_t *dptr = res.m[0]; for(int i=0; i<16; i++) { *dptr++ = *mptr++ * scalar; } return res; } Matrix4x4 operator *(scalar_t scalar, const Matrix4x4 &mat) { Matrix4x4 res; const scalar_t *mptr = mat.m[0]; scalar_t *dptr = res.m[0]; for(int i=0; i<16; i++) { *dptr++ = *mptr++ * scalar; } return res; } void operator *=(Matrix4x4 &mat, scalar_t scalar) { scalar_t *mptr = mat.m[0]; for(int i=0; i<16; i++) { *mptr++ *= scalar; } } void Matrix4x4::translate(const Vector3 &trans) { Matrix4x4 tmat(1, 0, 0, trans.x, 0, 1, 0, trans.y, 0, 0, 1, trans.z, 0, 0, 0, 1); *this *= tmat; } void Matrix4x4::set_translation(const Vector3 &trans) { *this = Matrix4x4(1, 0, 0, trans.x, 0, 1, 0, trans.y, 0, 0, 1, trans.z, 0, 0, 0, 1); } void Matrix4x4::rotate(const Vector3 &euler_angles) { Matrix3x3 xrot, yrot, zrot; xrot = Matrix3x3( 1, 0, 0, 0, cos(euler_angles.x), -sin(euler_angles.x), 0, sin(euler_angles.x), cos(euler_angles.x)); yrot = Matrix3x3( cos(euler_angles.y), 0, sin(euler_angles.y), 0, 1, 0, -sin(euler_angles.y), 0, cos(euler_angles.y)); zrot = Matrix3x3( cos(euler_angles.z), -sin(euler_angles.z), 0, sin(euler_angles.z), cos(euler_angles.z), 0, 0, 0, 1); *this *= Matrix4x4(xrot * yrot * zrot); } void Matrix4x4::set_rotation(const Vector3 &euler_angles) { Matrix3x3 xrot, yrot, zrot; xrot = Matrix3x3( 1, 0, 0, 0, cos(euler_angles.x), -sin(euler_angles.x), 0, sin(euler_angles.x), cos(euler_angles.x)); yrot = Matrix3x3( cos(euler_angles.y), 0, sin(euler_angles.y), 0, 1, 0, -sin(euler_angles.y), 0, cos(euler_angles.y)); zrot = Matrix3x3( cos(euler_angles.z), -sin(euler_angles.z), 0, sin(euler_angles.z), cos(euler_angles.z), 0, 0, 0, 1); *this = Matrix4x4(xrot * yrot * zrot); } void Matrix4x4::rotate(const Vector3 &axis, scalar_t angle) { scalar_t sina = (scalar_t)sin(angle); scalar_t cosa = (scalar_t)cos(angle); scalar_t invcosa = 1-cosa; scalar_t nxsq = axis.x * axis.x; scalar_t nysq = axis.y * axis.y; scalar_t nzsq = axis.z * axis.z; Matrix3x3 xform; xform[0][0] = nxsq + (1-nxsq) * cosa; xform[0][1] = axis.x * axis.y * invcosa - axis.z * sina; xform[0][2] = axis.x * axis.z * invcosa + axis.y * sina; xform[1][0] = axis.x * axis.y * invcosa + axis.z * sina; xform[1][1] = nysq + (1-nysq) * cosa; xform[1][2] = axis.y * axis.z * invcosa - axis.x * sina; xform[2][0] = axis.x * axis.z * invcosa - axis.y * sina; xform[2][1] = axis.y * axis.z * invcosa + axis.x * sina; xform[2][2] = nzsq + (1-nzsq) * cosa; *this *= Matrix4x4(xform); } void Matrix4x4::set_rotation(const Vector3 &axis, scalar_t angle) { scalar_t sina = (scalar_t)sin(angle); scalar_t cosa = (scalar_t)cos(angle); scalar_t invcosa = 1-cosa; scalar_t nxsq = axis.x * axis.x; scalar_t nysq = axis.y * axis.y; scalar_t nzsq = axis.z * axis.z; reset_identity(); m[0][0] = nxsq + (1-nxsq) * cosa; m[0][1] = axis.x * axis.y * invcosa - axis.z * sina; m[0][2] = axis.x * axis.z * invcosa + axis.y * sina; m[1][0] = axis.x * axis.y * invcosa + axis.z * sina; m[1][1] = nysq + (1-nysq) * cosa; m[1][2] = axis.y * axis.z * invcosa - axis.x * sina; m[2][0] = axis.x * axis.z * invcosa - axis.y * sina; m[2][1] = axis.y * axis.z * invcosa + axis.x * sina; m[2][2] = nzsq + (1-nzsq) * cosa; } void Matrix4x4::scale(const Vector4 &scale_vec) { Matrix4x4 smat( scale_vec.x, 0, 0, 0, 0, scale_vec.y, 0, 0, 0, 0, scale_vec.z, 0, 0, 0, 0, scale_vec.w); *this *= smat; } void Matrix4x4::set_scaling(const Vector4 &scale_vec) { *this = Matrix4x4( scale_vec.x, 0, 0, 0, 0, scale_vec.y, 0, 0, 0, 0, scale_vec.z, 0, 0, 0, 0, scale_vec.w); } void Matrix4x4::set_column_vector(const Vector4 &vec, unsigned int col_index) { m[0][col_index] = vec.x; m[1][col_index] = vec.y; m[2][col_index] = vec.z; m[3][col_index] = vec.w; } void Matrix4x4::set_row_vector(const Vector4 &vec, unsigned int row_index) { m[row_index][0] = vec.x; m[row_index][1] = vec.y; m[row_index][2] = vec.z; m[row_index][3] = vec.w; } Vector4 Matrix4x4::get_column_vector(unsigned int col_index) const { return Vector4(m[0][col_index], m[1][col_index], m[2][col_index], m[3][col_index]); } Vector4 Matrix4x4::get_row_vector(unsigned int row_index) const { return Vector4(m[row_index][0], m[row_index][1], m[row_index][2], m[row_index][3]); } void Matrix4x4::transpose() { Matrix4x4 tmp = *this; for(int i=0; i<4; i++) { for(int j=0; j<4; j++) { m[i][j] = tmp[j][i]; } } } Matrix4x4 Matrix4x4::transposed() const { Matrix4x4 res; for(int i=0; i<4; i++) { for(int j=0; j<4; j++) { res[i][j] = m[j][i]; } } return res; } scalar_t Matrix4x4::determinant() const { scalar_t det11 = (m[1][1] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[1][2] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) + (m[1][3] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])); scalar_t det12 = (m[1][0] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[1][2] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[1][3] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])); scalar_t det13 = (m[1][0] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) - (m[1][1] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[1][3] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); scalar_t det14 = (m[1][0] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])) - (m[1][1] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])) + (m[1][2] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); return m[0][0] * det11 - m[0][1] * det12 + m[0][2] * det13 - m[0][3] * det14; } Matrix4x4 Matrix4x4::adjoint() const { Matrix4x4 coef; coef.m[0][0] = (m[1][1] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[1][2] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) + (m[1][3] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])); coef.m[0][1] = (m[1][0] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[1][2] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[1][3] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])); coef.m[0][2] = (m[1][0] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) - (m[1][1] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[1][3] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); coef.m[0][3] = (m[1][0] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])) - (m[1][1] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])) + (m[1][2] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); coef.m[1][0] = (m[0][1] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[0][2] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) + (m[0][3] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])); coef.m[1][1] = (m[0][0] * (m[2][2] * m[3][3] - m[3][2] * m[2][3])) - (m[0][2] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[0][3] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])); coef.m[1][2] = (m[0][0] * (m[2][1] * m[3][3] - m[3][1] * m[2][3])) - (m[0][1] * (m[2][0] * m[3][3] - m[3][0] * m[2][3])) + (m[0][3] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); coef.m[1][3] = (m[0][0] * (m[2][1] * m[3][2] - m[3][1] * m[2][2])) - (m[0][1] * (m[2][0] * m[3][2] - m[3][0] * m[2][2])) + (m[0][2] * (m[2][0] * m[3][1] - m[3][0] * m[2][1])); coef.m[2][0] = (m[0][1] * (m[1][2] * m[3][3] - m[3][2] * m[1][3])) - (m[0][2] * (m[1][1] * m[3][3] - m[3][1] * m[1][3])) + (m[0][3] * (m[1][1] * m[3][2] - m[3][1] * m[1][2])); coef.m[2][1] = (m[0][0] * (m[1][2] * m[3][3] - m[3][2] * m[1][3])) - (m[0][2] * (m[1][0] * m[3][3] - m[3][0] * m[1][3])) + (m[0][3] * (m[1][0] * m[3][2] - m[3][0] * m[1][2])); coef.m[2][2] = (m[0][0] * (m[1][1] * m[3][3] - m[3][1] * m[1][3])) - (m[0][1] * (m[1][0] * m[3][3] - m[3][0] * m[1][3])) + (m[0][3] * (m[1][0] * m[3][1] - m[3][0] * m[1][1])); coef.m[2][3] = (m[0][0] * (m[1][1] * m[3][2] - m[3][1] * m[1][2])) - (m[0][1] * (m[1][0] * m[3][2] - m[3][0] * m[1][2])) + (m[0][2] * (m[1][0] * m[3][1] - m[3][0] * m[1][1])); coef.m[3][0] = (m[0][1] * (m[1][2] * m[2][3] - m[2][2] * m[1][3])) - (m[0][2] * (m[1][1] * m[2][3] - m[2][1] * m[1][3])) + (m[0][3] * (m[1][1] * m[2][2] - m[2][1] * m[1][2])); coef.m[3][1] = (m[0][0] * (m[1][2] * m[2][3] - m[2][2] * m[1][3])) - (m[0][2] * (m[1][0] * m[2][3] - m[2][0] * m[1][3])) + (m[0][3] * (m[1][0] * m[2][2] - m[2][0] * m[1][2])); coef.m[3][2] = (m[0][0] * (m[1][1] * m[2][3] - m[2][1] * m[1][3])) - (m[0][1] * (m[1][0] * m[2][3] - m[2][0] * m[1][3])) + (m[0][3] * (m[1][0] * m[2][1] - m[2][0] * m[1][1])); coef.m[3][3] = (m[0][0] * (m[1][1] * m[2][2] - m[2][1] * m[1][2])) - (m[0][1] * (m[1][0] * m[2][2] - m[2][0] * m[1][2])) + (m[0][2] * (m[1][0] * m[2][1] - m[2][0] * m[1][1])); coef.transpose(); for(int i=0; i<4; i++) { for(int j=0; j<4; j++) { coef.m[i][j] = j%2 ? -coef.m[i][j] : coef.m[i][j]; if(i%2) coef.m[i][j] = -coef.m[i][j]; } } return coef; } Matrix4x4 Matrix4x4::inverse() const { Matrix4x4 adj = adjoint(); return adj * (1.0f / determinant()); } ostream &operator <<(ostream &out, const Matrix4x4 &mat) { for(int i=0; i<4; i++) { char str[100]; sprintf(str, "[ %12.5f %12.5f %12.5f %12.5f ]\n", (float)mat.m[i][0], (float)mat.m[i][1], (float)mat.m[i][2], (float)mat.m[i][3]); out << str; } return out; }<|fim▁end|>
{ scalar_t sina = (scalar_t)sin(angle); scalar_t cosa = (scalar_t)cos(angle); scalar_t invcosa = 1-cosa;
<|file_name|>metadata_test.go<|end_file_name|><|fim▁begin|>package metadata import "testing" func TestGetLanguage(t *testing.T) { for _, l := range AllowedLanguages { if g, ok := GetLanguage(l.Name); !ok { t.Errorf("language defined but not found: %s", l.Name) } else if g != l { t.Errorf("found wrong language, expected %v, found %v", l, g) } } } func TestNoLanguage(t *testing.T) { langs := [...]string{"foobar language"} for _, l := range langs { if _, exist := GetLanguage(l); exist { t.Errorf("language found but should not exist: %s", l) } } } func TestRequiredLanguages(t *testing.T) { for _, l := range RequiredLanguages { if !l.Required { t.Errorf("language is required but not marked required: %s", l.Name) } if g, ok := GetLanguage(l.Name); !ok { t.Errorf("language required but not defined: %s", l.Name) } else if l != g { t.Errorf("required language different from the definition: %s", l.Name) } } for _, l := range AllowedLanguages { found := false for _, r := range RequiredLanguages { if l.Name == r.Name { found = true break<|fim▁hole|> if l.Required && !found { t.Errorf("language marked required but not in RequiredLanguages: %s", l.Name) } } } func TestGetLanguageFromExt(t *testing.T) { for _, l := range AllowedLanguages { if g, ok := GetLanguageFromExt(l.Ext); !ok { t.Errorf("cannot look up extension: %s", l.Ext) } else if l != g { t.Errorf("language different from definition: %s", l.Name) } } } func TestNoLanguageFromExt(t *testing.T) { langs := [...]string{"foo", "bar"} for _, l := range langs { if _, exist := GetLanguageFromExt(l); exist { t.Errorf("language found but should not exist: %s", l) } } }<|fim▁end|>
} }
<|file_name|>http_negotiate.cc<|end_file_name|><|fim▁begin|>// Copyright (c) 2011 The Chromium Authors. All rights reserved. // Use of this source code is governed by a BSD-style license that can be // found in the LICENSE file. #include "chrome_frame/http_negotiate.h" #include <atlbase.h> #include <atlcom.h> #include <htiframe.h> #include "base/logging.h" #include "base/memory/scoped_ptr.h" #include "base/string_util.h" #include "base/stringprintf.h" #include "base/utf_string_conversions.h" #include "chrome_frame/bho.h" #include "chrome_frame/exception_barrier.h" #include "chrome_frame/html_utils.h" #include "chrome_frame/urlmon_moniker.h" #include "chrome_frame/urlmon_url_request.h" #include "chrome_frame/utils.h" #include "chrome_frame/vtable_patch_manager.h" #include "net/http/http_response_headers.h" #include "net/http/http_util.h" bool HttpNegotiatePatch::modify_user_agent_ = true; const char kUACompatibleHttpHeader[] = "x-ua-compatible"; const char kLowerCaseUserAgent[] = "user-agent"; // From the latest urlmon.h. Symbol name prepended with LOCAL_ to // avoid conflict (and therefore build errors) for those building with // a newer Windows SDK. // TODO(robertshield): Remove this once we update our SDK version. const int LOCAL_BINDSTATUS_SERVER_MIMETYPEAVAILABLE = 54; static const int kHttpNegotiateBeginningTransactionIndex = 3; BEGIN_VTABLE_PATCHES(IHttpNegotiate) VTABLE_PATCH_ENTRY(kHttpNegotiateBeginningTransactionIndex, HttpNegotiatePatch::BeginningTransaction) END_VTABLE_PATCHES() namespace { class SimpleBindStatusCallback : public CComObjectRootEx<CComSingleThreadModel>, public IBindStatusCallback { public: BEGIN_COM_MAP(SimpleBindStatusCallback) COM_INTERFACE_ENTRY(IBindStatusCallback) END_COM_MAP()<|fim▁hole|> } STDMETHOD(GetPriority)(LONG* priority) { return E_NOTIMPL; } STDMETHOD(OnLowResource)(DWORD reserved) { return E_NOTIMPL; } STDMETHOD(OnProgress)(ULONG progress, ULONG max_progress, ULONG status_code, LPCWSTR status_text) { return E_NOTIMPL; } STDMETHOD(OnStopBinding)(HRESULT result, LPCWSTR error) { return E_NOTIMPL; } STDMETHOD(GetBindInfo)(DWORD* bind_flags, BINDINFO* bind_info) { return E_NOTIMPL; } STDMETHOD(OnDataAvailable)(DWORD flags, DWORD size, FORMATETC* formatetc, STGMEDIUM* storage) { return E_NOTIMPL; } STDMETHOD(OnObjectAvailable)(REFIID iid, IUnknown* object) { return E_NOTIMPL; } }; } // end namespace std::string AppendCFUserAgentString(LPCWSTR headers, LPCWSTR additional_headers) { using net::HttpUtil; std::string ascii_headers; if (additional_headers) { ascii_headers = WideToASCII(additional_headers); } // Extract "User-Agent" from |additional_headers| or |headers|. HttpUtil::HeadersIterator headers_iterator(ascii_headers.begin(), ascii_headers.end(), "\r\n"); std::string user_agent_value; if (headers_iterator.AdvanceTo(kLowerCaseUserAgent)) { user_agent_value = headers_iterator.values(); } else if (headers != NULL) { // See if there's a user-agent header specified in the original headers. std::string original_headers(WideToASCII(headers)); HttpUtil::HeadersIterator original_it(original_headers.begin(), original_headers.end(), "\r\n"); if (original_it.AdvanceTo(kLowerCaseUserAgent)) user_agent_value = original_it.values(); } // Use the default "User-Agent" if none was provided. if (user_agent_value.empty()) user_agent_value = http_utils::GetDefaultUserAgent(); // Now add chromeframe to it. user_agent_value = http_utils::AddChromeFrameToUserAgentValue( user_agent_value); // Build new headers, skip the existing user agent value from // existing headers. std::string new_headers; headers_iterator.Reset(); while (headers_iterator.GetNext()) { std::string name(headers_iterator.name()); if (!LowerCaseEqualsASCII(name, kLowerCaseUserAgent)) { new_headers += name + ": " + headers_iterator.values() + "\r\n"; } } new_headers += "User-Agent: " + user_agent_value; new_headers += "\r\n"; return new_headers; } std::string ReplaceOrAddUserAgent(LPCWSTR headers, const std::string& user_agent_value) { using net::HttpUtil; std::string new_headers; if (headers) { std::string ascii_headers(WideToASCII(headers)); // Extract "User-Agent" from the headers. HttpUtil::HeadersIterator headers_iterator(ascii_headers.begin(), ascii_headers.end(), "\r\n"); // Build new headers, skip the existing user agent value from // existing headers. while (headers_iterator.GetNext()) { std::string name(headers_iterator.name()); if (!LowerCaseEqualsASCII(name, kLowerCaseUserAgent)) { new_headers += name + ": " + headers_iterator.values() + "\r\n"; } } } new_headers += "User-Agent: " + user_agent_value; new_headers += "\r\n"; return new_headers; } HttpNegotiatePatch::HttpNegotiatePatch() { } HttpNegotiatePatch::~HttpNegotiatePatch() { } // static bool HttpNegotiatePatch::Initialize() { if (IS_PATCHED(IHttpNegotiate)) { DLOG(WARNING) << __FUNCTION__ << " called more than once."; return true; } // Use our SimpleBindStatusCallback class as we need a temporary object that // implements IBindStatusCallback. CComObjectStackEx<SimpleBindStatusCallback> request; base::win::ScopedComPtr<IBindCtx> bind_ctx; HRESULT hr = CreateAsyncBindCtx(0, &request, NULL, bind_ctx.Receive()); DCHECK(SUCCEEDED(hr)) << "CreateAsyncBindCtx"; if (bind_ctx) { base::win::ScopedComPtr<IUnknown> bscb_holder; bind_ctx->GetObjectParam(L"_BSCB_Holder_", bscb_holder.Receive()); if (bscb_holder) { hr = PatchHttpNegotiate(bscb_holder); } else { NOTREACHED() << "Failed to get _BSCB_Holder_"; hr = E_UNEXPECTED; } bind_ctx.Release(); } return SUCCEEDED(hr); } // static void HttpNegotiatePatch::Uninitialize() { vtable_patch::UnpatchInterfaceMethods(IHttpNegotiate_PatchInfo); } // static HRESULT HttpNegotiatePatch::PatchHttpNegotiate(IUnknown* to_patch) { DCHECK(to_patch); DCHECK_IS_NOT_PATCHED(IHttpNegotiate); base::win::ScopedComPtr<IHttpNegotiate> http; HRESULT hr = http.QueryFrom(to_patch); if (FAILED(hr)) { hr = DoQueryService(IID_IHttpNegotiate, to_patch, http.Receive()); } if (http) { hr = vtable_patch::PatchInterfaceMethods(http, IHttpNegotiate_PatchInfo); DLOG_IF(ERROR, FAILED(hr)) << base::StringPrintf("HttpNegotiate patch failed 0x%08X", hr); } else { DLOG(WARNING) << base::StringPrintf("IHttpNegotiate not supported 0x%08X", hr); } return hr; } // static HRESULT HttpNegotiatePatch::BeginningTransaction( IHttpNegotiate_BeginningTransaction_Fn original, IHttpNegotiate* me, LPCWSTR url, LPCWSTR headers, DWORD reserved, LPWSTR* additional_headers) { DVLOG(1) << __FUNCTION__ << " " << url << " headers:\n" << headers; HRESULT hr = original(me, url, headers, reserved, additional_headers); if (FAILED(hr)) { DLOG(WARNING) << __FUNCTION__ << " Delegate returned an error"; return hr; } if (modify_user_agent_) { std::string updated_headers; if (IsGcfDefaultRenderer() && RendererTypeForUrl(url) == RENDERER_TYPE_CHROME_DEFAULT_RENDERER) { // Replace the user-agent header with Chrome's. updated_headers = ReplaceOrAddUserAgent(*additional_headers, http_utils::GetChromeUserAgent()); } else { updated_headers = AppendCFUserAgentString(headers, *additional_headers); } *additional_headers = reinterpret_cast<wchar_t*>(::CoTaskMemRealloc( *additional_headers, (updated_headers.length() + 1) * sizeof(wchar_t))); lstrcpyW(*additional_headers, ASCIIToWide(updated_headers).c_str()); } else { // TODO(erikwright): Remove the user agent if it is present (i.e., because // of PostPlatform setting in the registry). } return S_OK; }<|fim▁end|>
// IBindStatusCallback implementation STDMETHOD(OnStartBinding)(DWORD reserved, IBinding* binding) { return E_NOTIMPL;
<|file_name|>settings.py<|end_file_name|><|fim▁begin|># Django settings for wireframe project. import os PROJECT_DIR = os.path.dirname(__file__) DEBUG = True TEMPLATE_DEBUG = DEBUG ADMINS = ( # ('Your Name', '[email protected]'), ) MANAGERS = ADMINS DATABASE_ENGINE = 'sqlite3' # 'postgresql_psycopg2', 'postgresql', 'mysql', 'sqlite3' or 'oracle'. DATABASE_NAME = 'wire.db' # Or path to database file if using sqlite3. DATABASE_USER = '' # Not used with sqlite3. DATABASE_PASSWORD = '' # Not used with sqlite3. DATABASE_HOST = '' # Set to empty string for localhost. Not used with sqlite3. DATABASE_PORT = '' # Set to empty string for default. Not used with sqlite3. DATABASES = { 'default': { 'ENGINE': 'django.db.backends.sqlite3', 'NAME': 'wire.db' } } # Local time zone for this installation. Choices can be found here: # http://en.wikipedia.org/wiki/List_of_tz_zones_by_name # although not all choices may be available on all operating systems. # If running in a Windows environment this must be set to the same as your # system time zone. TIME_ZONE = 'America/Chicago' # Language code for this installation. All choices can be found here: # http://www.i18nguy.com/unicode/language-identifiers.html LANGUAGE_CODE = 'en-us' SITE_ID = 1 # If you set this to False, Django will make some optimizations so as not # to load the internationalization machinery. USE_I18N = True # Absolute path to the directory that holds media. WIREFRAME_MEDIA_ROOT = os.path.join(PROJECT_DIR, os.pardir, 'wireframes', 'media', 'wireframes') ADMIN_MEDIA_ROOT = os.path.join(PROJECT_DIR, os.pardir, 'admin_media', '') MEDIA_URL = '/media/' ADMIN_MEDIA_PREFIX = '/admin_media/' # Make this unique, and don't share it with anybody. SECRET_KEY = 'p)vc32rphaob@!7nze8@6ih5c_@ygjc%@csf*6^+d^((+%$4p#' TEMPLATE_LOADERS = ( ('django.template.loaders.cached.Loader', ( 'django.template.loaders.filesystem.Loader', 'django.template.loaders.app_directories.Loader', )), ) MIDDLEWARE_CLASSES = (<|fim▁hole|> 'django.middleware.locale.LocaleMiddleware', ) ROOT_URLCONF = 'example.urls' TEMPLATE_DIRS = ( # Put strings here, like "/home/html/django_templates" or "C:/www/django/templates". # Always use forward slashes, even on Windows. # Don't forget to use absolute paths, not relative paths. os.path.join(os.path.dirname(__file__), "templates"), ) TEMPLATE_CONTEXT_PROCESSORS = ( "django.contrib.auth.context_processors.auth", "django.core.context_processors.i18n", "django.core.context_processors.debug", "django.core.context_processors.request", "django.core.context_processors.media", ) INSTALLED_APPS = ( 'django.contrib.admin', 'django.contrib.auth', 'django.contrib.contenttypes', 'django.contrib.sessions', 'wireframes', )<|fim▁end|>
'django.middleware.common.CommonMiddleware', 'django.contrib.sessions.middleware.SessionMiddleware', 'django.contrib.auth.middleware.AuthenticationMiddleware', #'django.middleware.doc.XViewMiddleware',
<|file_name|>test_util.py<|end_file_name|><|fim▁begin|>""" Unit tests for utility functions.<|fim▁hole|> from thrifty import util @pytest.mark.parametrize("num", [15, 16]) def test_fft_bin(num): """Validate fft_bin against numpy's fftfreq function.""" expected = np.fft.fftfreq(num, 1./num) got = np.array([util.fft_bin(i, num) for i in range(num)]) np.testing.assert_array_equal(got, expected)<|fim▁end|>
""" import numpy as np import pytest
<|file_name|>test_server_external_events.py<|end_file_name|><|fim▁begin|># Copyright 2014 Red Hat, Inc. # # Licensed under the Apache License, Version 2.0 (the "License"); you may # not use this file except in compliance with the License. You may obtain # a copy of the License at # # http://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, WITHOUT # WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the # License for the specific language governing permissions and limitations # under the License. import json import mock import webob from nova.api.openstack.compute.contrib import server_external_events from nova import context from nova import exception from nova.objects import instance as instance_obj from nova import test fake_instances = { '00000000-0000-0000-0000-000000000001': instance_obj.Instance( uuid='00000000-0000-0000-0000-000000000001', host='host1'), '00000000-0000-0000-0000-000000000002': instance_obj.Instance( uuid='00000000-0000-0000-0000-000000000002', host='host1'), '00000000-0000-0000-0000-000000000003': instance_obj.Instance( uuid='00000000-0000-0000-0000-000000000003', host='host2'), '00000000-0000-0000-0000-000000000004': instance_obj.Instance( uuid='00000000-0000-0000-0000-000000000004', host=None), } fake_instance_uuids = sorted(fake_instances.keys()) MISSING_UUID = '00000000-0000-0000-0000-000000000005' @classmethod def fake_get_by_uuid(cls, context, uuid): try: return fake_instances[uuid] except KeyError: raise exception.InstanceNotFound(instance_id=uuid) @mock.patch('nova.objects.instance.Instance.get_by_uuid', fake_get_by_uuid) class ServerExternalEventsTest(test.NoDBTestCase): def setUp(self): super(ServerExternalEventsTest, self).setUp() self.api = server_external_events.ServerExternalEventsController() self.context = context.get_admin_context() self.event_1 = {'name': 'network-vif-plugged', 'tag': 'foo', 'server_uuid': fake_instance_uuids[0]} self.event_2 = {'name': 'network-changed', 'server_uuid': fake_instance_uuids[1]} self.default_body = {'events': [self.event_1, self.event_2]} self.resp_event_1 = dict(self.event_1) self.resp_event_1['code'] = 200 self.resp_event_1['status'] = 'completed' self.resp_event_2 = dict(self.event_2) self.resp_event_2['code'] = 200 self.resp_event_2['status'] = 'completed' self.default_resp_body = {'events': [self.resp_event_1, self.resp_event_2]} def _create_req(self, body): req = webob.Request.blank('/v2/fake/os-server-external-events') req.method = 'POST' req.headers['content-type'] = 'application/json' req.environ['nova.context'] = self.context req.body = json.dumps(body) return req def _assert_call(self, req, body, expected_uuids, expected_events): with mock.patch.object(self.api.compute_api, 'external_instance_event') as api_method: response = self.api.create(req, body) result = response.obj code = response._code self.assertEqual(1, api_method.call_count) for inst in api_method.call_args_list[0][0][1]: expected_uuids.remove(inst.uuid) self.assertEqual([], expected_uuids) for event in api_method.call_args_list[0][0][2]: expected_events.remove(event.name) self.assertEqual([], expected_events) return result, code def test_create(self):<|fim▁hole|> req = self._create_req(self.default_body) result, code = self._assert_call(req, self.default_body, fake_instance_uuids[:2], ['network-vif-plugged', 'network-changed']) self.assertEqual(self.default_resp_body, result) self.assertEqual(200, code) def test_create_one_bad_instance(self): body = self.default_body body['events'][1]['server_uuid'] = MISSING_UUID req = self._create_req(body) result, code = self._assert_call(req, body, [fake_instance_uuids[0]], ['network-vif-plugged']) self.assertEqual('failed', result['events'][1]['status']) self.assertEqual(200, result['events'][0]['code']) self.assertEqual(404, result['events'][1]['code']) self.assertEqual(207, code) def test_create_event_instance_has_no_host(self): body = self.default_body body['events'][0]['server_uuid'] = fake_instance_uuids[-1] req = self._create_req(body) # the instance without host should not be passed to the compute layer result, code = self._assert_call(req, body, [fake_instance_uuids[1]], ['network-changed']) self.assertEqual(422, result['events'][0]['code']) self.assertEqual('failed', result['events'][0]['status']) self.assertEqual(200, result['events'][1]['code']) self.assertEqual(207, code) def test_create_no_good_instances(self): body = self.default_body body['events'][0]['server_uuid'] = MISSING_UUID body['events'][1]['server_uuid'] = MISSING_UUID req = self._create_req(body) self.assertRaises(webob.exc.HTTPNotFound, self.api.create, req, body) def test_create_bad_status(self): body = self.default_body body['events'][1]['status'] = 'foo' req = self._create_req(body) self.assertRaises(webob.exc.HTTPBadRequest, self.api.create, req, body) def test_create_extra_gorp(self): body = self.default_body body['events'][0]['foobar'] = 'bad stuff' req = self._create_req(body) self.assertRaises(webob.exc.HTTPBadRequest, self.api.create, req, body) def test_create_bad_events(self): body = {'events': 'foo'} req = self._create_req(body) self.assertRaises(webob.exc.HTTPBadRequest, self.api.create, req, body) def test_create_bad_body(self): body = {'foo': 'bar'} req = self._create_req(body) self.assertRaises(webob.exc.HTTPBadRequest, self.api.create, req, body)<|fim▁end|>
<|file_name|>dispatcher.py<|end_file_name|><|fim▁begin|>import re import asyncio import threading from collections import defaultdict def connector(bot, dispatcher, NICK, CHANNELS, PASSWORD=None): @bot.on('client_connect') async def connect(**kwargs): bot.send('USER', user=NICK, realname=NICK) if PASSWORD: bot.send('PASS', password=PASSWORD) bot.send('NICK', nick=NICK) # Don't try to join channels until the server has # sent the MOTD, or signaled that there's no MOTD. done, pending = await asyncio.wait( [bot.wait("RPL_ENDOFMOTD"), bot.wait("ERR_NOMOTD")], loop=bot.loop, return_when=asyncio.FIRST_COMPLETED ) # Cancel whichever waiter's event didn't come in. for future in pending: future.cancel() for channel in CHANNELS: bot.send('JOIN', channel=channel) @bot.on('client_disconnect') async def reconnect(**kwargs): # Wait a second so we don't flood await asyncio.sleep(5, loop=bot.loop) # Schedule a connection when the loop's next available bot.loop.create_task(bot.connect()) # Wait until client_connect has triggered await bot.wait("client_connect") @bot.on('ping') def keepalive(message, **kwargs): bot.send('PONG', message=message) @bot.on('privmsg') def message(host, target, message, **kwargs): if host == NICK: # don't process messages from the bot itself return if target == NICK: # private message dispatcher.handle_private_message(host, message) else: # channel message dispatcher.handle_channel_message(host, target, message) class Dispatcher(object): def __init__(self, client): self.client = client self._callbacks = [] self.register_callbacks() def _register_callbacks(self, callbacks): """\ Hook for registering custom callbacks for dispatch patterns """ self._callbacks.extend(callbacks) def register_callbacks(self): """\ Hook for registering callbacks with connection -- handled by __init__() """ self._register_callbacks(( (re.compile(pattern), callback) for pattern, callback in self.command_patterns() )) def _process_command(self, nick, message, channel): results = [] for pattern, callback in self._callbacks: match = pattern.search(message) or pattern.search('/privmsg') if match: results.append( callback(nick, message, channel, **match.groupdict())) return results def handle_private_message(self, nick, message): for result in self._process_command(nick, message, None): if result: self.respond(result, nick=nick) def handle_channel_message(self, nick, channel, message): for result in self._process_command(nick, message, channel): if result: self.respond(result, channel=channel) def command_patterns(self): """\ Hook for defining callbacks, stored as a tuple of 2-tuples: return ( ('/join', self.room_greeter), ('!find (^\s+)', self.handle_find), ) """ raise NotImplementedError def respond(self, message, channel=None, nick=None): """\ Multipurpose method for sending responses to channel or via message to<|fim▁hole|> if not channel.startswith('#'): channel = '#%s' % channel self.client.send('PRIVMSG', target=channel, message=message) elif nick: self.client.send('PRIVMSG', target=nick, message=message) class Locker(object): def __init__(self, delay=None, user=""): self.delay = delay if delay or delay == 0 and type(delay) == int else 5 self.locked = False def lock(self): if not self.locked: if self.delay > 0: self.locked = True t = threading.Timer(self.delay, self.unlock, ()) t.daemon = True t.start() return self.locked def unlock(self): self.locked = False return self.locked def cooldown(delay): def decorator(func): if not hasattr(func, "__cooldowns"): func.__cooldowns = defaultdict(lambda: Locker(delay)) def inner(*args, **kwargs): nick = args[1] user_cd = func.__cooldowns[nick] if user_cd.locked: return ret = func(*args, **kwargs) user_cd.lock() return ret return inner return decorator<|fim▁end|>
a single user """ if channel:
<|file_name|>db.go<|end_file_name|><|fim▁begin|>// Copyright 2017 The go-ethereum Authors // This file is part of go-ethereum. // // go-ethereum is free software: you can redistribute it and/or modify // it under the terms of the GNU General Public License as published by // the Free Software Foundation, either version 3 of the License, or // (at your option) any later version. // // go-ethereum is distributed in the hope that it will be useful, // but WITHOUT ANY WARRANTY; without even the implied warranty of // MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the // GNU General Public License for more details. // // You should have received a copy of the GNU General Public License // along with go-ethereum. If not, see <http://www.gnu.org/licenses/>. package main import ( "fmt" "io" "os" "path/filepath" "github.com/akroma-project/akroma/cmd/utils" "github.com/akroma-project/akroma/common" "github.com/akroma-project/akroma/log" "github.com/akroma-project/akroma/swarm/storage" "gopkg.in/urfave/cli.v1" ) var dbCommand = cli.Command{ Name: "db", CustomHelpTemplate: helpTemplate, Usage: "manage the local chunk database", ArgsUsage: "db COMMAND", Description: "Manage the local chunk database", Subcommands: []cli.Command{ { Action: dbExport, CustomHelpTemplate: helpTemplate, Name: "export",<|fim▁hole|> ArgsUsage: "<chunkdb> <file>", Description: ` Export a local chunk database as a tar archive (use - to send to stdout). swarm db export ~/.ethereum/swarm/bzz-KEY/chunks chunks.tar The export may be quite large, consider piping the output through the Unix pv(1) tool to get a progress bar: swarm db export ~/.ethereum/swarm/bzz-KEY/chunks - | pv > chunks.tar `, }, { Action: dbImport, CustomHelpTemplate: helpTemplate, Name: "import", Usage: "import chunks from a tar archive into a local chunk database (use - to read from stdin)", ArgsUsage: "<chunkdb> <file>", Description: `Import chunks from a tar archive into a local chunk database (use - to read from stdin). swarm db import ~/.ethereum/swarm/bzz-KEY/chunks chunks.tar The import may be quite large, consider piping the input through the Unix pv(1) tool to get a progress bar: pv chunks.tar | swarm db import ~/.ethereum/swarm/bzz-KEY/chunks -`, }, }, } func dbExport(ctx *cli.Context) { args := ctx.Args() if len(args) != 3 { utils.Fatalf("invalid arguments, please specify both <chunkdb> (path to a local chunk database), <file> (path to write the tar archive to, - for stdout) and the base key") } store, err := openLDBStore(args[0], common.Hex2Bytes(args[2])) if err != nil { utils.Fatalf("error opening local chunk database: %s", err) } defer store.Close() var out io.Writer if args[1] == "-" { out = os.Stdout } else { f, err := os.Create(args[1]) if err != nil { utils.Fatalf("error opening output file: %s", err) } defer f.Close() out = f } count, err := store.Export(out) if err != nil { utils.Fatalf("error exporting local chunk database: %s", err) } log.Info(fmt.Sprintf("successfully exported %d chunks", count)) } func dbImport(ctx *cli.Context) { args := ctx.Args() if len(args) != 3 { utils.Fatalf("invalid arguments, please specify both <chunkdb> (path to a local chunk database), <file> (path to read the tar archive from, - for stdin) and the base key") } store, err := openLDBStore(args[0], common.Hex2Bytes(args[2])) if err != nil { utils.Fatalf("error opening local chunk database: %s", err) } defer store.Close() var in io.Reader if args[1] == "-" { in = os.Stdin } else { f, err := os.Open(args[1]) if err != nil { utils.Fatalf("error opening input file: %s", err) } defer f.Close() in = f } count, err := store.Import(in) if err != nil { utils.Fatalf("error importing local chunk database: %s", err) } log.Info(fmt.Sprintf("successfully imported %d chunks", count)) } func openLDBStore(path string, basekey []byte) (*storage.LDBStore, error) { if _, err := os.Stat(filepath.Join(path, "CURRENT")); err != nil { return nil, fmt.Errorf("invalid chunkdb path: %s", err) } storeparams := storage.NewDefaultStoreParams() ldbparams := storage.NewLDBStoreParams(storeparams, path) ldbparams.BaseKey = basekey return storage.NewLDBStore(ldbparams) }<|fim▁end|>
Usage: "export a local chunk database as a tar archive (use - to send to stdout)",
<|file_name|>mission_select.rs<|end_file_name|><|fim▁begin|>use voodoo::window::{Point, Window}; use game_state::{UiState, ModelView}; const TITLE: [&'static str; 6] = [ "██████╗ ███████╗ ██╗██╗ ██╗ █████╗ ██████╗██╗ ██╗", "██╔══██╗██╔════╝ ██╔╝██║ ██║██╔══██╗██╔════╝██║ ██╔╝", "█████╔╝█████╗ ██╔╝ ███████║███████║██║ █████╔╝", "██╔══██╗██╔══╝ ██╔╝ ██╔══██║██╔══██║██║ ██╔═██╗", "█║ ██║███████╗██╔╝ ██║ ██║██║ ██║╚██████╗██║ ██╗", "╚═╝ ╚═╝╚══════╝╚═╝ ╚═╝ ╚═╝╚═╝ ╚═╝ ╚═════╝╚═╝ ╚═╝", ]; pub enum UiEvent { KeyPressed, Tick, } <|fim▁hole|> pub struct State { window: Window, } impl State { pub fn new(window: Window) -> State { State { window: window, } } } impl ::std::fmt::Debug for State { fn fmt(&self, f: &mut ::std::fmt::Formatter) -> ::std::fmt::Result { write!(f, "mission_select::State") } } pub fn next(_state: &mut State, event: UiEvent, _mv: &mut ModelView) -> Transition { use self::UiEvent::*; match event { KeyPressed => Transition::Level(0), Tick => Transition::Ui(UiState::Unselected), } } pub fn display(mission_state: &mut State, compositor: &mut ::voodoo::compositor::Compositor, _mv: &mut ModelView) { for (offset, line) in TITLE.iter().enumerate() { mission_state.window.print_at(Point::new(13, 6 + offset as u16), *line); } mission_state.window.print_at(Point::new(30, 14), "PRESS ANY KEY TO BEGIN"); mission_state.window.print_at(Point::new(33, 15), "PRESS Q TO QUIT"); mission_state.window.refresh(compositor); }<|fim▁end|>
pub enum Transition { Ui(UiState), Level(usize), }
<|file_name|>profile_fibonacci_raw.py<|end_file_name|><|fim▁begin|>import profile def fib(n): # from literateprograms.org # http://bit.ly/hlOQ5m if n == 0: return 0<|fim▁hole|> return fib(n - 1) + fib(n - 2) def fib_seq(n): seq = [] if n > 0: seq.extend(fib_seq(n - 1)) seq.append(fib(n)) return seq profile.run('print(fib_seq(20)); print()')<|fim▁end|>
elif n == 1: return 1 else:
<|file_name|>raw.rs<|end_file_name|><|fim▁begin|>// Copyright 2015 The Rust Project Developers. See the COPYRIGHT // file at the top-level directory of this distribution and at // http://rust-lang.org/COPYRIGHT. // // Licensed under the Apache License, Version 2.0 <LICENSE-APACHE or // http://www.apache.org/licenses/LICENSE-2.0> or the MIT license // <LICENSE-MIT or http://opensource.org/licenses/MIT>, at your // option. This file may not be copied, modified, or distributed // except according to those terms. //! Raw OS-specific types for the current platform/architecture #![unstable(feature = "raw_os", reason = "recently added API")] #[cfg(target_arch = "aarch64")] pub type c_char = u8; #[cfg(not(target_arch = "aarch64"))] pub type c_char = i8; pub type c_schar = i8; pub type c_uchar = u8; pub type c_short = i16; pub type c_ushort = u16; pub type c_int = i32; pub type c_uint = u32; #[cfg(any(target_pointer_width = "32", windows))] pub type c_long = i32; #[cfg(any(target_pointer_width = "32", windows))] pub type c_ulong = u32; #[cfg(all(target_pointer_width = "64", not(windows)))] pub type c_long = i64; #[cfg(all(target_pointer_width = "64", not(windows)))] pub type c_ulong = u64; pub type c_longlong = i64; pub type c_ulonglong = u64; pub type c_float = f32; pub type c_double = f64; /// Type used to construct void pointers for use with C. /// /// This type is only useful as a pointer target. Do not use it as a /// return type for FFI functions which have the `void` return type in /// C. Use the unit type `()` or omit the return type instead. // NB: For LLVM to recognize the void pointer type and by extension // functions like malloc(), we need to have it represented as i8* in // LLVM bitcode. The enum used here ensures this and prevents misuse // of the "raw" type by only having private variants.. We need two // variants, because the compiler complains about the repr attribute // otherwise. #[repr(u8)] pub enum c_void { #[doc(hidden)] __variant1, #[doc(hidden)] __variant2, } #[cfg(test)] mod tests { use any::TypeId; use libc; use mem; macro_rules! ok { ($($t:ident)*) => {$( assert!(TypeId::of::<libc::$t>() == TypeId::of::<raw::$t>(), "{} is wrong", stringify!($t)); )*} } macro_rules! ok_size { ($($t:ident)*) => {$( assert!(mem::size_of::<libc::$t>() == mem::size_of::<raw::$t>(), "{} is wrong", stringify!($t)); )*} } #[test] fn same() { use os::raw; ok!(c_char c_schar c_uchar c_short c_ushort c_int c_uint c_long c_ulong c_longlong c_ulonglong c_float c_double);<|fim▁hole|> } #[cfg(unix)] fn unix() { { use os::unix::raw; ok!(uid_t gid_t dev_t ino_t mode_t nlink_t off_t blksize_t blkcnt_t); } { use sys::platform::raw; ok_size!(stat); } } #[cfg(windows)] fn windows() { use os::windows::raw; } }<|fim▁end|>
<|file_name|>analytics01.js<|end_file_name|><|fim▁begin|>//baidu var _bdhmProtocol = (("https:" == document.location.protocol) ? " https://" : " http://"); document.write(unescape("%3Cscript src='" + _bdhmProtocol + "hm.baidu.com/h.js%3F4233e74dff0ae5bd0a3d81c6ccf756e6' type='text/javascript'%3E%3C/script%3E")); //google analytics (function(i,s,o,g,r,a,m){i['GoogleAnalyticsObject']=r;i[r]=i[r]||function(){ (i[r].q=i[r].q||[]).push(arguments)},i[r].l=1*new Date();a=s.createElement(o),<|fim▁hole|> /* ga('create', 'UA-41268416-1', 'lagou.com'); ga('send', 'pageview');*/ ga('create', 'UA-41268416-1', 'lagou.com', { 'allowLinker': true }); ga('require', 'linker'); ga('linker:autoLink', ['lagoujobs.com'],true ); ga('send', 'pageview');<|fim▁end|>
m=s.getElementsByTagName(o)[0];a.async=1;a.src=g;m.parentNode.insertBefore(a,m) })(window,document,'script','//www.google-analytics.com/analytics.js','ga');
<|file_name|>vengine_cpy.py<|end_file_name|><|fim▁begin|>import sys, imp from . import model, ffiplatform class VCPythonEngine(object): _class_key = 'x' _gen_python_module = True def __init__(self, verifier): self.verifier = verifier self.ffi = verifier.ffi self._struct_pending_verification = {} self._types_of_builtin_functions = {} def patch_extension_kwds(self, kwds): pass def find_module(self, module_name, path, so_suffixes): try: f, filename, descr = imp.find_module(module_name, path) except ImportError: return None if f is not None: f.close() # Note that after a setuptools installation, there are both .py # and .so files with the same basename. The code here relies on # imp.find_module() locating the .so in priority. if descr[0] not in so_suffixes: return None return filename def collect_types(self): self._typesdict = {} self._generate("collecttype") def _prnt(self, what=''): self._f.write(what + '\n') def _gettypenum(self, type): # a KeyError here is a bug. please report it! :-) return self._typesdict[type] def _do_collect_type(self, tp): if ((not isinstance(tp, model.PrimitiveType) or tp.name == 'long double') and tp not in self._typesdict): num = len(self._typesdict) self._typesdict[tp] = num def write_source_to_f(self): self.collect_types() # # The new module will have a _cffi_setup() function that receives # objects from the ffi world, and that calls some setup code in # the module. This setup code is split in several independent # functions, e.g. one per constant. The functions are "chained" # by ending in a tail call to each other. # # This is further split in two chained lists, depending on if we # can do it at import-time or if we must wait for _cffi_setup() to # provide us with the <ctype> objects. This is needed because we # need the values of the enum constants in order to build the # <ctype 'enum'> that we may have to pass to _cffi_setup(). # # The following two 'chained_list_constants' items contains # the head of these two chained lists, as a string that gives the # call to do, if any. self._chained_list_constants = ['((void)lib,0)', '((void)lib,0)'] # prnt = self._prnt # first paste some standard set of lines that are mostly '#define' prnt(cffimod_header) prnt() # then paste the C source given by the user, verbatim. prnt(self.verifier.preamble) prnt() # # call generate_cpy_xxx_decl(), for every xxx found from # ffi._parser._declarations. This generates all the functions. self._generate("decl") # # implement the function _cffi_setup_custom() as calling the # head of the chained list. self._generate_setup_custom() prnt() # # produce the method table, including the entries for the # generated Python->C function wrappers, which are done # by generate_cpy_function_method(). prnt('static PyMethodDef _cffi_methods[] = {') self._generate("method") prnt(' {"_cffi_setup", _cffi_setup, METH_VARARGS, NULL},') prnt(' {NULL, NULL, 0, NULL} /* Sentinel */') prnt('};') prnt() # # standard init. modname = self.verifier.get_module_name() constants = self._chained_list_constants[False] prnt('#if PY_MAJOR_VERSION >= 3') prnt() prnt('static struct PyModuleDef _cffi_module_def = {') prnt(' PyModuleDef_HEAD_INIT,') prnt(' "%s",' % modname) prnt(' NULL,') prnt(' -1,') prnt(' _cffi_methods,') prnt(' NULL, NULL, NULL, NULL') prnt('};') prnt() prnt('PyMODINIT_FUNC') prnt('PyInit_%s(void)' % modname) prnt('{') prnt(' PyObject *lib;') prnt(' lib = PyModule_Create(&_cffi_module_def);') prnt(' if (lib == NULL)') prnt(' return NULL;') prnt(' if (%s < 0 || _cffi_init() < 0) {' % (constants,)) prnt(' Py_DECREF(lib);') prnt(' return NULL;') prnt(' }') prnt(' return lib;') prnt('}') prnt() prnt('#else') prnt() prnt('PyMODINIT_FUNC') prnt('init%s(void)' % modname) prnt('{') prnt(' PyObject *lib;') prnt(' lib = Py_InitModule("%s", _cffi_methods);' % modname) prnt(' if (lib == NULL)') prnt(' return;') prnt(' if (%s < 0 || _cffi_init() < 0)' % (constants,)) prnt(' return;') prnt(' return;') prnt('}') prnt() prnt('#endif') def load_library(self, flags=None): # XXX review all usages of 'self' here! # import it as a new extension module imp.acquire_lock() try: if hasattr(sys, "getdlopenflags"): previous_flags = sys.getdlopenflags() try: if hasattr(sys, "setdlopenflags") and flags is not None: sys.setdlopenflags(flags) module = imp.load_dynamic(self.verifier.get_module_name(), self.verifier.modulefilename) except ImportError as e: error = "importing %r: %s" % (self.verifier.modulefilename, e) raise ffiplatform.VerificationError(error) finally: if hasattr(sys, "setdlopenflags"): sys.setdlopenflags(previous_flags) finally: imp.release_lock() # # call loading_cpy_struct() to get the struct layout inferred by # the C compiler<|fim▁hole|> revmapping = dict([(value, key) for (key, value) in self._typesdict.items()]) lst = [revmapping[i] for i in range(len(revmapping))] lst = list(map(self.ffi._get_cached_btype, lst)) # # build the FFILibrary class and instance and call _cffi_setup(). # this will set up some fields like '_cffi_types', and only then # it will invoke the chained list of functions that will really # build (notably) the constant objects, as <cdata> if they are # pointers, and store them as attributes on the 'library' object. class FFILibrary(object): _cffi_python_module = module _cffi_ffi = self.ffi _cffi_dir = [] def __dir__(self): return FFILibrary._cffi_dir + list(self.__dict__) library = FFILibrary() if module._cffi_setup(lst, ffiplatform.VerificationError, library): import warnings warnings.warn("reimporting %r might overwrite older definitions" % (self.verifier.get_module_name())) # # finally, call the loaded_cpy_xxx() functions. This will perform # the final adjustments, like copying the Python->C wrapper # functions from the module to the 'library' object, and setting # up the FFILibrary class with properties for the global C variables. self._load(module, 'loaded', library=library) module._cffi_original_ffi = self.ffi module._cffi_types_of_builtin_funcs = self._types_of_builtin_functions return library def _get_declarations(self): return sorted(self.ffi._parser._declarations.items()) def _generate(self, step_name): for name, tp in self._get_declarations(): kind, realname = name.split(' ', 1) try: method = getattr(self, '_generate_cpy_%s_%s' % (kind, step_name)) except AttributeError: raise ffiplatform.VerificationError( "not implemented in verify(): %r" % name) try: method(tp, realname) except Exception as e: model.attach_exception_info(e, name) raise def _load(self, module, step_name, **kwds): for name, tp in self._get_declarations(): kind, realname = name.split(' ', 1) method = getattr(self, '_%s_cpy_%s' % (step_name, kind)) try: method(tp, realname, module, **kwds) except Exception as e: model.attach_exception_info(e, name) raise def _generate_nothing(self, tp, name): pass def _loaded_noop(self, tp, name, module, **kwds): pass # ---------- def _convert_funcarg_to_c(self, tp, fromvar, tovar, errcode): extraarg = '' if isinstance(tp, model.PrimitiveType): if tp.is_integer_type() and tp.name != '_Bool': converter = '_cffi_to_c_int' extraarg = ', %s' % tp.name else: converter = '(%s)_cffi_to_c_%s' % (tp.get_c_name(''), tp.name.replace(' ', '_')) errvalue = '-1' # elif isinstance(tp, model.PointerType): self._convert_funcarg_to_c_ptr_or_array(tp, fromvar, tovar, errcode) return # elif isinstance(tp, (model.StructOrUnion, model.EnumType)): # a struct (not a struct pointer) as a function argument self._prnt(' if (_cffi_to_c((char *)&%s, _cffi_type(%d), %s) < 0)' % (tovar, self._gettypenum(tp), fromvar)) self._prnt(' %s;' % errcode) return # elif isinstance(tp, model.FunctionPtrType): converter = '(%s)_cffi_to_c_pointer' % tp.get_c_name('') extraarg = ', _cffi_type(%d)' % self._gettypenum(tp) errvalue = 'NULL' # else: raise NotImplementedError(tp) # self._prnt(' %s = %s(%s%s);' % (tovar, converter, fromvar, extraarg)) self._prnt(' if (%s == (%s)%s && PyErr_Occurred())' % ( tovar, tp.get_c_name(''), errvalue)) self._prnt(' %s;' % errcode) def _extra_local_variables(self, tp, localvars): if isinstance(tp, model.PointerType): localvars.add('Py_ssize_t datasize') def _convert_funcarg_to_c_ptr_or_array(self, tp, fromvar, tovar, errcode): self._prnt(' datasize = _cffi_prepare_pointer_call_argument(') self._prnt(' _cffi_type(%d), %s, (char **)&%s);' % ( self._gettypenum(tp), fromvar, tovar)) self._prnt(' if (datasize != 0) {') self._prnt(' if (datasize < 0)') self._prnt(' %s;' % errcode) self._prnt(' %s = alloca((size_t)datasize);' % (tovar,)) self._prnt(' memset((void *)%s, 0, (size_t)datasize);' % (tovar,)) self._prnt(' if (_cffi_convert_array_from_object(' '(char *)%s, _cffi_type(%d), %s) < 0)' % ( tovar, self._gettypenum(tp), fromvar)) self._prnt(' %s;' % errcode) self._prnt(' }') def _convert_expr_from_c(self, tp, var, context): if isinstance(tp, model.PrimitiveType): if tp.is_integer_type(): return '_cffi_from_c_int(%s, %s)' % (var, tp.name) elif tp.name != 'long double': return '_cffi_from_c_%s(%s)' % (tp.name.replace(' ', '_'), var) else: return '_cffi_from_c_deref((char *)&%s, _cffi_type(%d))' % ( var, self._gettypenum(tp)) elif isinstance(tp, (model.PointerType, model.FunctionPtrType)): return '_cffi_from_c_pointer((char *)%s, _cffi_type(%d))' % ( var, self._gettypenum(tp)) elif isinstance(tp, model.ArrayType): return '_cffi_from_c_pointer((char *)%s, _cffi_type(%d))' % ( var, self._gettypenum(model.PointerType(tp.item))) elif isinstance(tp, model.StructType): if tp.fldnames is None: raise TypeError("'%s' is used as %s, but is opaque" % ( tp._get_c_name(), context)) return '_cffi_from_c_struct((char *)&%s, _cffi_type(%d))' % ( var, self._gettypenum(tp)) elif isinstance(tp, model.EnumType): return '_cffi_from_c_deref((char *)&%s, _cffi_type(%d))' % ( var, self._gettypenum(tp)) else: raise NotImplementedError(tp) # ---------- # typedefs: generates no code so far _generate_cpy_typedef_collecttype = _generate_nothing _generate_cpy_typedef_decl = _generate_nothing _generate_cpy_typedef_method = _generate_nothing _loading_cpy_typedef = _loaded_noop _loaded_cpy_typedef = _loaded_noop # ---------- # function declarations def _generate_cpy_function_collecttype(self, tp, name): assert isinstance(tp, model.FunctionPtrType) if tp.ellipsis: self._do_collect_type(tp) else: # don't call _do_collect_type(tp) in this common case, # otherwise test_autofilled_struct_as_argument fails for type in tp.args: self._do_collect_type(type) self._do_collect_type(tp.result) def _generate_cpy_function_decl(self, tp, name): assert isinstance(tp, model.FunctionPtrType) if tp.ellipsis: # cannot support vararg functions better than this: check for its # exact type (including the fixed arguments), and build it as a # constant function pointer (no CPython wrapper) self._generate_cpy_const(False, name, tp) return prnt = self._prnt numargs = len(tp.args) if numargs == 0: argname = 'noarg' elif numargs == 1: argname = 'arg0' else: argname = 'args' prnt('static PyObject *') prnt('_cffi_f_%s(PyObject *self, PyObject *%s)' % (name, argname)) prnt('{') # context = 'argument of %s' % name for i, type in enumerate(tp.args): prnt(' %s;' % type.get_c_name(' x%d' % i, context)) # localvars = set() for type in tp.args: self._extra_local_variables(type, localvars) for decl in localvars: prnt(' %s;' % (decl,)) # if not isinstance(tp.result, model.VoidType): result_code = 'result = ' context = 'result of %s' % name prnt(' %s;' % tp.result.get_c_name(' result', context)) else: result_code = '' # if len(tp.args) > 1: rng = range(len(tp.args)) for i in rng: prnt(' PyObject *arg%d;' % i) prnt() prnt(' if (!PyArg_ParseTuple(args, "%s:%s", %s))' % ( 'O' * numargs, name, ', '.join(['&arg%d' % i for i in rng]))) prnt(' return NULL;') prnt() # for i, type in enumerate(tp.args): self._convert_funcarg_to_c(type, 'arg%d' % i, 'x%d' % i, 'return NULL') prnt() # prnt(' Py_BEGIN_ALLOW_THREADS') prnt(' _cffi_restore_errno();') prnt(' { %s%s(%s); }' % ( result_code, name, ', '.join(['x%d' % i for i in range(len(tp.args))]))) prnt(' _cffi_save_errno();') prnt(' Py_END_ALLOW_THREADS') prnt() # prnt(' (void)self; /* unused */') if numargs == 0: prnt(' (void)noarg; /* unused */') if result_code: prnt(' return %s;' % self._convert_expr_from_c(tp.result, 'result', 'result type')) else: prnt(' Py_INCREF(Py_None);') prnt(' return Py_None;') prnt('}') prnt() def _generate_cpy_function_method(self, tp, name): if tp.ellipsis: return numargs = len(tp.args) if numargs == 0: meth = 'METH_NOARGS' elif numargs == 1: meth = 'METH_O' else: meth = 'METH_VARARGS' self._prnt(' {"%s", _cffi_f_%s, %s, NULL},' % (name, name, meth)) _loading_cpy_function = _loaded_noop def _loaded_cpy_function(self, tp, name, module, library): if tp.ellipsis: return func = getattr(module, name) setattr(library, name, func) self._types_of_builtin_functions[func] = tp # ---------- # named structs _generate_cpy_struct_collecttype = _generate_nothing def _generate_cpy_struct_decl(self, tp, name): assert name == tp.name self._generate_struct_or_union_decl(tp, 'struct', name) def _generate_cpy_struct_method(self, tp, name): self._generate_struct_or_union_method(tp, 'struct', name) def _loading_cpy_struct(self, tp, name, module): self._loading_struct_or_union(tp, 'struct', name, module) def _loaded_cpy_struct(self, tp, name, module, **kwds): self._loaded_struct_or_union(tp) _generate_cpy_union_collecttype = _generate_nothing def _generate_cpy_union_decl(self, tp, name): assert name == tp.name self._generate_struct_or_union_decl(tp, 'union', name) def _generate_cpy_union_method(self, tp, name): self._generate_struct_or_union_method(tp, 'union', name) def _loading_cpy_union(self, tp, name, module): self._loading_struct_or_union(tp, 'union', name, module) def _loaded_cpy_union(self, tp, name, module, **kwds): self._loaded_struct_or_union(tp) def _generate_struct_or_union_decl(self, tp, prefix, name): if tp.fldnames is None: return # nothing to do with opaque structs checkfuncname = '_cffi_check_%s_%s' % (prefix, name) layoutfuncname = '_cffi_layout_%s_%s' % (prefix, name) cname = ('%s %s' % (prefix, name)).strip() # prnt = self._prnt prnt('static void %s(%s *p)' % (checkfuncname, cname)) prnt('{') prnt(' /* only to generate compile-time warnings or errors */') prnt(' (void)p;') for fname, ftype, fbitsize in tp.enumfields(): if (isinstance(ftype, model.PrimitiveType) and ftype.is_integer_type()) or fbitsize >= 0: # accept all integers, but complain on float or double prnt(' (void)((p->%s) << 1);' % fname) else: # only accept exactly the type declared. try: prnt(' { %s = &p->%s; (void)tmp; }' % ( ftype.get_c_name('*tmp', 'field %r'%fname), fname)) except ffiplatform.VerificationError as e: prnt(' /* %s */' % str(e)) # cannot verify it, ignore prnt('}') prnt('static PyObject *') prnt('%s(PyObject *self, PyObject *noarg)' % (layoutfuncname,)) prnt('{') prnt(' struct _cffi_aligncheck { char x; %s y; };' % cname) prnt(' static Py_ssize_t nums[] = {') prnt(' sizeof(%s),' % cname) prnt(' offsetof(struct _cffi_aligncheck, y),') for fname, ftype, fbitsize in tp.enumfields(): if fbitsize >= 0: continue # xxx ignore fbitsize for now prnt(' offsetof(%s, %s),' % (cname, fname)) if isinstance(ftype, model.ArrayType) and ftype.length is None: prnt(' 0, /* %s */' % ftype._get_c_name()) else: prnt(' sizeof(((%s *)0)->%s),' % (cname, fname)) prnt(' -1') prnt(' };') prnt(' (void)self; /* unused */') prnt(' (void)noarg; /* unused */') prnt(' return _cffi_get_struct_layout(nums);') prnt(' /* the next line is not executed, but compiled */') prnt(' %s(0);' % (checkfuncname,)) prnt('}') prnt() def _generate_struct_or_union_method(self, tp, prefix, name): if tp.fldnames is None: return # nothing to do with opaque structs layoutfuncname = '_cffi_layout_%s_%s' % (prefix, name) self._prnt(' {"%s", %s, METH_NOARGS, NULL},' % (layoutfuncname, layoutfuncname)) def _loading_struct_or_union(self, tp, prefix, name, module): if tp.fldnames is None: return # nothing to do with opaque structs layoutfuncname = '_cffi_layout_%s_%s' % (prefix, name) # function = getattr(module, layoutfuncname) layout = function() if isinstance(tp, model.StructOrUnion) and tp.partial: # use the function()'s sizes and offsets to guide the # layout of the struct totalsize = layout[0] totalalignment = layout[1] fieldofs = layout[2::2] fieldsize = layout[3::2] tp.force_flatten() assert len(fieldofs) == len(fieldsize) == len(tp.fldnames) tp.fixedlayout = fieldofs, fieldsize, totalsize, totalalignment else: cname = ('%s %s' % (prefix, name)).strip() self._struct_pending_verification[tp] = layout, cname def _loaded_struct_or_union(self, tp): if tp.fldnames is None: return # nothing to do with opaque structs self.ffi._get_cached_btype(tp) # force 'fixedlayout' to be considered if tp in self._struct_pending_verification: # check that the layout sizes and offsets match the real ones def check(realvalue, expectedvalue, msg): if realvalue != expectedvalue: raise ffiplatform.VerificationError( "%s (we have %d, but C compiler says %d)" % (msg, expectedvalue, realvalue)) ffi = self.ffi BStruct = ffi._get_cached_btype(tp) layout, cname = self._struct_pending_verification.pop(tp) check(layout[0], ffi.sizeof(BStruct), "wrong total size") check(layout[1], ffi.alignof(BStruct), "wrong total alignment") i = 2 for fname, ftype, fbitsize in tp.enumfields(): if fbitsize >= 0: continue # xxx ignore fbitsize for now check(layout[i], ffi.offsetof(BStruct, fname), "wrong offset for field %r" % (fname,)) if layout[i+1] != 0: BField = ffi._get_cached_btype(ftype) check(layout[i+1], ffi.sizeof(BField), "wrong size for field %r" % (fname,)) i += 2 assert i == len(layout) # ---------- # 'anonymous' declarations. These are produced for anonymous structs # or unions; the 'name' is obtained by a typedef. _generate_cpy_anonymous_collecttype = _generate_nothing def _generate_cpy_anonymous_decl(self, tp, name): if isinstance(tp, model.EnumType): self._generate_cpy_enum_decl(tp, name, '') else: self._generate_struct_or_union_decl(tp, '', name) def _generate_cpy_anonymous_method(self, tp, name): if not isinstance(tp, model.EnumType): self._generate_struct_or_union_method(tp, '', name) def _loading_cpy_anonymous(self, tp, name, module): if isinstance(tp, model.EnumType): self._loading_cpy_enum(tp, name, module) else: self._loading_struct_or_union(tp, '', name, module) def _loaded_cpy_anonymous(self, tp, name, module, **kwds): if isinstance(tp, model.EnumType): self._loaded_cpy_enum(tp, name, module, **kwds) else: self._loaded_struct_or_union(tp) # ---------- # constants, likely declared with '#define' def _generate_cpy_const(self, is_int, name, tp=None, category='const', vartp=None, delayed=True, size_too=False, check_value=None): prnt = self._prnt funcname = '_cffi_%s_%s' % (category, name) prnt('static int %s(PyObject *lib)' % funcname) prnt('{') prnt(' PyObject *o;') prnt(' int res;') if not is_int: prnt(' %s;' % (vartp or tp).get_c_name(' i', name)) else: assert category == 'const' # if check_value is not None: self._check_int_constant_value(name, check_value) # if not is_int: if category == 'var': realexpr = '&' + name else: realexpr = name prnt(' i = (%s);' % (realexpr,)) prnt(' o = %s;' % (self._convert_expr_from_c(tp, 'i', 'variable type'),)) assert delayed else: prnt(' o = _cffi_from_c_int_const(%s);' % name) prnt(' if (o == NULL)') prnt(' return -1;') if size_too: prnt(' {') prnt(' PyObject *o1 = o;') prnt(' o = Py_BuildValue("On", o1, (Py_ssize_t)sizeof(%s));' % (name,)) prnt(' Py_DECREF(o1);') prnt(' if (o == NULL)') prnt(' return -1;') prnt(' }') prnt(' res = PyObject_SetAttrString(lib, "%s", o);' % name) prnt(' Py_DECREF(o);') prnt(' if (res < 0)') prnt(' return -1;') prnt(' return %s;' % self._chained_list_constants[delayed]) self._chained_list_constants[delayed] = funcname + '(lib)' prnt('}') prnt() def _generate_cpy_constant_collecttype(self, tp, name): is_int = isinstance(tp, model.PrimitiveType) and tp.is_integer_type() if not is_int: self._do_collect_type(tp) def _generate_cpy_constant_decl(self, tp, name): is_int = isinstance(tp, model.PrimitiveType) and tp.is_integer_type() self._generate_cpy_const(is_int, name, tp) _generate_cpy_constant_method = _generate_nothing _loading_cpy_constant = _loaded_noop _loaded_cpy_constant = _loaded_noop # ---------- # enums def _check_int_constant_value(self, name, value, err_prefix=''): prnt = self._prnt if value <= 0: prnt(' if ((%s) > 0 || (long)(%s) != %dL) {' % ( name, name, value)) else: prnt(' if ((%s) <= 0 || (unsigned long)(%s) != %dUL) {' % ( name, name, value)) prnt(' char buf[64];') prnt(' if ((%s) <= 0)' % name) prnt(' snprintf(buf, 63, "%%ld", (long)(%s));' % name) prnt(' else') prnt(' snprintf(buf, 63, "%%lu", (unsigned long)(%s));' % name) prnt(' PyErr_Format(_cffi_VerificationError,') prnt(' "%s%s has the real value %s, not %s",') prnt(' "%s", "%s", buf, "%d");' % ( err_prefix, name, value)) prnt(' return -1;') prnt(' }') def _enum_funcname(self, prefix, name): # "$enum_$1" => "___D_enum____D_1" name = name.replace('$', '___D_') return '_cffi_e_%s_%s' % (prefix, name) def _generate_cpy_enum_decl(self, tp, name, prefix='enum'): if tp.partial: for enumerator in tp.enumerators: self._generate_cpy_const(True, enumerator, delayed=False) return # funcname = self._enum_funcname(prefix, name) prnt = self._prnt prnt('static int %s(PyObject *lib)' % funcname) prnt('{') for enumerator, enumvalue in zip(tp.enumerators, tp.enumvalues): self._check_int_constant_value(enumerator, enumvalue, "enum %s: " % name) prnt(' return %s;' % self._chained_list_constants[True]) self._chained_list_constants[True] = funcname + '(lib)' prnt('}') prnt() _generate_cpy_enum_collecttype = _generate_nothing _generate_cpy_enum_method = _generate_nothing def _loading_cpy_enum(self, tp, name, module): if tp.partial: enumvalues = [getattr(module, enumerator) for enumerator in tp.enumerators] tp.enumvalues = tuple(enumvalues) tp.partial_resolved = True def _loaded_cpy_enum(self, tp, name, module, library): for enumerator, enumvalue in zip(tp.enumerators, tp.enumvalues): setattr(library, enumerator, enumvalue) # ---------- # macros: for now only for integers def _generate_cpy_macro_decl(self, tp, name): if tp == '...': check_value = None else: check_value = tp # an integer self._generate_cpy_const(True, name, check_value=check_value) _generate_cpy_macro_collecttype = _generate_nothing _generate_cpy_macro_method = _generate_nothing _loading_cpy_macro = _loaded_noop _loaded_cpy_macro = _loaded_noop # ---------- # global variables def _generate_cpy_variable_collecttype(self, tp, name): if isinstance(tp, model.ArrayType): tp_ptr = model.PointerType(tp.item) else: tp_ptr = model.PointerType(tp) self._do_collect_type(tp_ptr) def _generate_cpy_variable_decl(self, tp, name): if isinstance(tp, model.ArrayType): tp_ptr = model.PointerType(tp.item) self._generate_cpy_const(False, name, tp, vartp=tp_ptr, size_too = (tp.length == '...')) else: tp_ptr = model.PointerType(tp) self._generate_cpy_const(False, name, tp_ptr, category='var') _generate_cpy_variable_method = _generate_nothing _loading_cpy_variable = _loaded_noop def _loaded_cpy_variable(self, tp, name, module, library): value = getattr(library, name) if isinstance(tp, model.ArrayType): # int a[5] is "constant" in the # sense that "a=..." is forbidden if tp.length == '...': assert isinstance(value, tuple) (value, size) = value BItemType = self.ffi._get_cached_btype(tp.item) length, rest = divmod(size, self.ffi.sizeof(BItemType)) if rest != 0: raise ffiplatform.VerificationError( "bad size: %r does not seem to be an array of %s" % (name, tp.item)) tp = tp.resolve_length(length) # 'value' is a <cdata 'type *'> which we have to replace with # a <cdata 'type[N]'> if the N is actually known if tp.length is not None: BArray = self.ffi._get_cached_btype(tp) value = self.ffi.cast(BArray, value) setattr(library, name, value) return # remove ptr=<cdata 'int *'> from the library instance, and replace # it by a property on the class, which reads/writes into ptr[0]. ptr = value delattr(library, name) def getter(library): return ptr[0] def setter(library, value): ptr[0] = value setattr(type(library), name, property(getter, setter)) type(library)._cffi_dir.append(name) # ---------- def _generate_setup_custom(self): prnt = self._prnt prnt('static int _cffi_setup_custom(PyObject *lib)') prnt('{') prnt(' return %s;' % self._chained_list_constants[True]) prnt('}') cffimod_header = r''' #include <Python.h> #include <stddef.h> /* this block of #ifs should be kept exactly identical between c/_cffi_backend.c, cffi/vengine_cpy.py, cffi/vengine_gen.py */ #if defined(_MSC_VER) # include <malloc.h> /* for alloca() */ # if _MSC_VER < 1600 /* MSVC < 2010 */ typedef __int8 int8_t; typedef __int16 int16_t; typedef __int32 int32_t; typedef __int64 int64_t; typedef unsigned __int8 uint8_t; typedef unsigned __int16 uint16_t; typedef unsigned __int32 uint32_t; typedef unsigned __int64 uint64_t; typedef __int8 int_least8_t; typedef __int16 int_least16_t; typedef __int32 int_least32_t; typedef __int64 int_least64_t; typedef unsigned __int8 uint_least8_t; typedef unsigned __int16 uint_least16_t; typedef unsigned __int32 uint_least32_t; typedef unsigned __int64 uint_least64_t; typedef __int8 int_fast8_t; typedef __int16 int_fast16_t; typedef __int32 int_fast32_t; typedef __int64 int_fast64_t; typedef unsigned __int8 uint_fast8_t; typedef unsigned __int16 uint_fast16_t; typedef unsigned __int32 uint_fast32_t; typedef unsigned __int64 uint_fast64_t; typedef __int64 intmax_t; typedef unsigned __int64 uintmax_t; # else # include <stdint.h> # endif # if _MSC_VER < 1800 /* MSVC < 2013 */ typedef unsigned char _Bool; # endif #else # include <stdint.h> # if (defined (__SVR4) && defined (__sun)) || defined(_AIX) # include <alloca.h> # endif #endif #if PY_MAJOR_VERSION < 3 # undef PyCapsule_CheckExact # undef PyCapsule_GetPointer # define PyCapsule_CheckExact(capsule) (PyCObject_Check(capsule)) # define PyCapsule_GetPointer(capsule, name) \ (PyCObject_AsVoidPtr(capsule)) #endif #if PY_MAJOR_VERSION >= 3 # define PyInt_FromLong PyLong_FromLong #endif #define _cffi_from_c_double PyFloat_FromDouble #define _cffi_from_c_float PyFloat_FromDouble #define _cffi_from_c_long PyInt_FromLong #define _cffi_from_c_ulong PyLong_FromUnsignedLong #define _cffi_from_c_longlong PyLong_FromLongLong #define _cffi_from_c_ulonglong PyLong_FromUnsignedLongLong #define _cffi_to_c_double PyFloat_AsDouble #define _cffi_to_c_float PyFloat_AsDouble #define _cffi_from_c_int_const(x) \ (((x) > 0) ? \ ((unsigned long long)(x) <= (unsigned long long)LONG_MAX) ? \ PyInt_FromLong((long)(x)) : \ PyLong_FromUnsignedLongLong((unsigned long long)(x)) : \ ((long long)(x) >= (long long)LONG_MIN) ? \ PyInt_FromLong((long)(x)) : \ PyLong_FromLongLong((long long)(x))) #define _cffi_from_c_int(x, type) \ (((type)-1) > 0 ? /* unsigned */ \ (sizeof(type) < sizeof(long) ? \ PyInt_FromLong((long)x) : \ sizeof(type) == sizeof(long) ? \ PyLong_FromUnsignedLong((unsigned long)x) : \ PyLong_FromUnsignedLongLong((unsigned long long)x)) : \ (sizeof(type) <= sizeof(long) ? \ PyInt_FromLong((long)x) : \ PyLong_FromLongLong((long long)x))) #define _cffi_to_c_int(o, type) \ ((type)( \ sizeof(type) == 1 ? (((type)-1) > 0 ? (type)_cffi_to_c_u8(o) \ : (type)_cffi_to_c_i8(o)) : \ sizeof(type) == 2 ? (((type)-1) > 0 ? (type)_cffi_to_c_u16(o) \ : (type)_cffi_to_c_i16(o)) : \ sizeof(type) == 4 ? (((type)-1) > 0 ? (type)_cffi_to_c_u32(o) \ : (type)_cffi_to_c_i32(o)) : \ sizeof(type) == 8 ? (((type)-1) > 0 ? (type)_cffi_to_c_u64(o) \ : (type)_cffi_to_c_i64(o)) : \ (Py_FatalError("unsupported size for type " #type), (type)0))) #define _cffi_to_c_i8 \ ((int(*)(PyObject *))_cffi_exports[1]) #define _cffi_to_c_u8 \ ((int(*)(PyObject *))_cffi_exports[2]) #define _cffi_to_c_i16 \ ((int(*)(PyObject *))_cffi_exports[3]) #define _cffi_to_c_u16 \ ((int(*)(PyObject *))_cffi_exports[4]) #define _cffi_to_c_i32 \ ((int(*)(PyObject *))_cffi_exports[5]) #define _cffi_to_c_u32 \ ((unsigned int(*)(PyObject *))_cffi_exports[6]) #define _cffi_to_c_i64 \ ((long long(*)(PyObject *))_cffi_exports[7]) #define _cffi_to_c_u64 \ ((unsigned long long(*)(PyObject *))_cffi_exports[8]) #define _cffi_to_c_char \ ((int(*)(PyObject *))_cffi_exports[9]) #define _cffi_from_c_pointer \ ((PyObject *(*)(char *, CTypeDescrObject *))_cffi_exports[10]) #define _cffi_to_c_pointer \ ((char *(*)(PyObject *, CTypeDescrObject *))_cffi_exports[11]) #define _cffi_get_struct_layout \ ((PyObject *(*)(Py_ssize_t[]))_cffi_exports[12]) #define _cffi_restore_errno \ ((void(*)(void))_cffi_exports[13]) #define _cffi_save_errno \ ((void(*)(void))_cffi_exports[14]) #define _cffi_from_c_char \ ((PyObject *(*)(char))_cffi_exports[15]) #define _cffi_from_c_deref \ ((PyObject *(*)(char *, CTypeDescrObject *))_cffi_exports[16]) #define _cffi_to_c \ ((int(*)(char *, CTypeDescrObject *, PyObject *))_cffi_exports[17]) #define _cffi_from_c_struct \ ((PyObject *(*)(char *, CTypeDescrObject *))_cffi_exports[18]) #define _cffi_to_c_wchar_t \ ((wchar_t(*)(PyObject *))_cffi_exports[19]) #define _cffi_from_c_wchar_t \ ((PyObject *(*)(wchar_t))_cffi_exports[20]) #define _cffi_to_c_long_double \ ((long double(*)(PyObject *))_cffi_exports[21]) #define _cffi_to_c__Bool \ ((_Bool(*)(PyObject *))_cffi_exports[22]) #define _cffi_prepare_pointer_call_argument \ ((Py_ssize_t(*)(CTypeDescrObject *, PyObject *, char **))_cffi_exports[23]) #define _cffi_convert_array_from_object \ ((int(*)(char *, CTypeDescrObject *, PyObject *))_cffi_exports[24]) #define _CFFI_NUM_EXPORTS 25 typedef struct _ctypedescr CTypeDescrObject; static void *_cffi_exports[_CFFI_NUM_EXPORTS]; static PyObject *_cffi_types, *_cffi_VerificationError; static int _cffi_setup_custom(PyObject *lib); /* forward */ static PyObject *_cffi_setup(PyObject *self, PyObject *args) { PyObject *library; int was_alive = (_cffi_types != NULL); (void)self; /* unused */ if (!PyArg_ParseTuple(args, "OOO", &_cffi_types, &_cffi_VerificationError, &library)) return NULL; Py_INCREF(_cffi_types); Py_INCREF(_cffi_VerificationError); if (_cffi_setup_custom(library) < 0) return NULL; return PyBool_FromLong(was_alive); } static int _cffi_init(void) { PyObject *module, *c_api_object = NULL; module = PyImport_ImportModule("_cffi_backend"); if (module == NULL) goto failure; c_api_object = PyObject_GetAttrString(module, "_C_API"); if (c_api_object == NULL) goto failure; if (!PyCapsule_CheckExact(c_api_object)) { PyErr_SetNone(PyExc_ImportError); goto failure; } memcpy(_cffi_exports, PyCapsule_GetPointer(c_api_object, "cffi"), _CFFI_NUM_EXPORTS * sizeof(void *)); Py_DECREF(module); Py_DECREF(c_api_object); return 0; failure: Py_XDECREF(module); Py_XDECREF(c_api_object); return -1; } #define _cffi_type(num) ((CTypeDescrObject *)PyList_GET_ITEM(_cffi_types, num)) /**********/ '''<|fim▁end|>
self._load(module, 'loading') # # the C code will need the <ctype> objects. Collect them in # order in a list.
<|file_name|>processor.py<|end_file_name|><|fim▁begin|>import base64 import hashlib import logging import re import urllib import urlparse import xmlrpclib import redis import requests import lxml.html from django.conf import settings from django.core.exceptions import ValidationError from django.core.files.base import ContentFile from django.db import transaction from django.utils.timezone import utc from crate.web.history.models import Event from crate.web.packages.models import Package, Release, TroveClassifier from crate.web.packages.models import ReleaseRequire, ReleaseProvide, ReleaseObsolete, ReleaseURI, ReleaseFile from crate.pypi.exceptions import PackageHashMismatch from crate.pypi.models import PyPIMirrorPage, PyPIServerSigPage from crate.pypi.utils.serversigs import load_key, verify logger = logging.getLogger(__name__) INDEX_URL = "http://pypi.python.org/pypi" SIMPLE_URL = "http://pypi.python.org/simple/" SERVERSIG_URL = "http://pypi.python.org/serversig/" SERVERKEY_URL = "http://pypi.python.org/serverkey" SERVERKEY_KEY = "crate:pypi:serverkey" _disutils2_version_capture = re.compile("^(.*?)(?:\(([^()]+)\))?$") _md5_re = re.compile(r"(https?://pypi\.python\.org/packages/.+)#md5=([a-f0-9]+)") def get_helper(data, key, default=None): if data.get(key) and data[key] != "UNKNOWN": return data[key] return "" if default is None else default def split_meta(meta): meta_split = meta.split(";", 1) meta_name, meta_version = _disutils2_version_capture.search(meta_split[0].strip()).groups() meta_env = meta_split[1].strip() if len(meta_split) == 2 else "" return { "name": meta_name, "version": meta_version if meta_version is not None else "", "environment": meta_env, } class PyPIPackage(object): def __init__(self, name, version=None): self.name = name self.version = version self.stored = False self.pypi = xmlrpclib.ServerProxy(INDEX_URL, use_datetime=True) self.datastore = redis.StrictRedis(**dict([(x.lower(), y) for x, y in settings.REDIS[settings.PYPI_DATASTORE].items()])) def process(self, bulk=False, download=True, skip_modified=True): self.bulk = bulk self.skip_modified = skip_modified self.fetch() self.build() with transaction.commit_on_success(): self.store() if download: self.download() def delete(self): with transaction.commit_on_success(): self.verify_and_sync_pages() if self.version is None: # Delete the entire package packages = Package.objects.filter(name=self.name).select_for_update() releases = Release.objects.filter(package__in=packages).select_for_update() for package in packages: package.delete() else: # Delete only this release try: package = Package.objects.get(name=self.name) except Package.DoesNotExist: return releases = Release.objects.filter(package=package, version=self.version).select_for_update() for release in releases: release.hidden = True release.save() def remove_files(self, *files): self.verify_and_sync_pages() packages = Package.objects.filter(name=self.name) releases = Release.objects.filter(package__in=packages) for rf in ReleaseFile.objects.filter(release__in=releases, filename__in=files): rf.hidden = True rf.save() def fetch(self): logger.debug("[FETCH] %s%s" % (self.name, " %s" % self.version if self.version else "")) # Fetch meta data for this release self.releases = self.get_releases() self.release_data = self.get_release_data() self.release_url_data = self.get_release_urls() def build(self): logger.debug("[BUILD] %s%s" % (self.name, " %s" % self.version if self.version else "")) # Check to Make sure fetch has been ran if not hasattr(self, "releases") or not hasattr(self, "release_data") or not hasattr(self, "release_url_data"): raise Exception("fetch must be called prior to running build") # @@@ Make a Custom Exception # Construct our representation of the releases self.data = {} for release in self.releases: data = {} data["package"] = self.name data["version"] = release data["author"] = get_helper(self.release_data[release], "author") data["author_email"] = get_helper(self.release_data[release], "author_email") data["maintainer"] = get_helper(self.release_data[release], "maintainer") data["maintainer_email"] = get_helper(self.release_data[release], "maintainer_email") data["summary"] = get_helper(self.release_data[release], "summary") data["description"] = get_helper(self.release_data[release], "description") data["license"] = get_helper(self.release_data[release], "license") data["keywords"] = get_helper(self.release_data[release], "keywords") # @@@ Switch This to a List data["platform"] = get_helper(self.release_data[release], "platform") data["download_uri"] = get_helper(self.release_data[release], "download_url") # @@@ Should This Go Under URI? data["requires_python"] = get_helper(self.release_data[release], "required_python") data["stable_version"] = get_helper(self.release_data[release], "stable_version") # @@@ What Is This? data["classifiers"] = get_helper(self.release_data[release], "classifiers", []) # Construct the URIs data["uris"] = {} if get_helper(self.release_data[release], "home_page"): data["uris"]["Home Page"] = get_helper(self.release_data[release], "home_page") if get_helper(self.release_data[release], "bugtrack_url"): data["uris"]["Bug Tracker"] = get_helper(self.release_data[release], "bugtrack_url") for label, url in [x.split(",", 1) for x in get_helper(self.release_data[release], "project_url", [])]: data["uris"][label] = url # Construct Requires data["requires"] = [] for kind in ["requires", "requires_dist", "requires_external"]: for require in get_helper(self.release_data[release], kind, []): req = {"kind": kind if kind is not "requires_external" else "external"} req.update(split_meta(require)) data["requires"].append(req) # Construct Provides data["provides"] = [] for kind in ["provides", "provides_dist"]: for provides in get_helper(self.release_data[release], kind, []): req = {"kind": kind} req.update(split_meta(provides)) data["provides"].append(req) # Construct Obsoletes data["obsoletes"] = [] for kind in ["obsoletes", "obsoletes_dist"]: for provides in get_helper(self.release_data[release], kind, []): req = {"kind": kind} req.update(split_meta(provides)) data["obsoletes"].append(req) # Construct Files data["files"] = [] for url_data in self.release_url_data[release]: data["files"].append({ "comment": get_helper(url_data, "comment_text"), "downloads": get_helper(url_data, "downloads", 0), "file": get_helper(url_data, "url"), "filename": get_helper(url_data, "filename"), "python_version": get_helper(url_data, "python_version"), "type": get_helper(url_data, "packagetype"), "digests": { "md5": url_data["md5_digest"].lower(), } }) if url_data.get("upload_time"): data["files"][-1]["created"] = url_data["upload_time"].replace(tzinfo=utc) for file_data in data["files"]: if file_data.get("created"): if data.get("created"): if file_data["created"] < data["created"]: data["created"] = file_data["created"] else: data["created"] = file_data["created"] self.data[release] = data logger.debug("[RELEASE BUILD DATA] %s %s %s" % (self.name, release, data)) def store(self): try: package = Package.objects.get(normalized_name=re.sub('[^A-Za-z0-9.]+', '-', self.name).lower()) if package.name != self.name: package.name = self.name package.save() except Package.DoesNotExist: package = Package.objects.create(name=self.name) for data in self.data.values(): try: release = Release.objects.get(package=package, version=data["version"]) except Release.DoesNotExist: release = Release(package=package, version=data["version"]) release.full_clean() release.save() # This is an extra database call but it should prevent ShareLocks Release.objects.filter(pk=release.pk).select_for_update() if release.hidden: release.hidden = False for key, value in data.iteritems(): if key in ["package", "version"]: # Short circuit package and version continue if key == "uris": ReleaseURI.objects.filter(release=release).delete() for label, uri in value.iteritems(): try: ReleaseURI.objects.get(release=release, label=label, uri=uri) except ReleaseURI.DoesNotExist: try: release_uri = ReleaseURI(release=release, label=label, uri=uri) release_uri.full_clean() release_uri.save(force_insert=True) except ValidationError: logger.exception("%s, %s for %s-%s Invalid Data" % (label, uri, release.package.name, release.version)) elif key == "classifiers": release.classifiers.clear() for classifier in value: try: trove = TroveClassifier.objects.get(trove=classifier) except TroveClassifier.DoesNotExist: trove = TroveClassifier(trove=classifier) trove.full_clean() trove.save(force_insert=True) release.classifiers.add(trove) elif key in ["requires", "provides", "obsoletes"]: model = {"requires": ReleaseRequire, "provides": ReleaseProvide, "obsoletes": ReleaseObsolete}.get(key) model.objects.filter(release=release).delete() for item in value: try: model.objects.get(release=release, **item) except model.DoesNotExist: m = model(release=release, **item) m.full_clean() m.save(force_insert=True) elif key == "files": files = ReleaseFile.objects.filter(release=release) filenames = dict([(x.filename, x) for x in files]) for f in value: try: rf = ReleaseFile.objects.get( release=release, type=f["type"], filename=f["filename"], python_version=f["python_version"], ) for k, v in f.iteritems(): if k in ["digests", "file", "filename", "type", "python_version"]: continue setattr(rf, k, v) rf.hidden = False rf.full_clean() rf.save() except ReleaseFile.DoesNotExist: rf = ReleaseFile( release=release, type=f["type"], filename=f["filename"], python_version=f["python_version"], **dict([(k, v) for k, v in f.iteritems() if k not in ["digests", "file", "filename", "type", "python_version"]]) ) rf.hidden = False rf.full_clean() rf.save() if f["filename"] in filenames.keys(): del filenames[f["filename"]] if filenames: for rf in ReleaseFile.objects.filter(pk__in=[f.pk for f in filenames.values()]): rf.hidden = True rf.save() else: setattr(release, key, value) while True: try: release.full_clean() except ValidationError as e: if "download_uri" in e.message_dict: release.download_uri = "" logger.exception("%s-%s Release Validation Error %s" % (release.package.name, release.version, str(e.message_dict))) else: raise else: break release.save() # Mark unsynced as deleted when bulk processing if self.bulk: for release in Release.objects.filter(package=package).exclude(version__in=self.data.keys()): release.hidden = True release.save() self.stored = True def download(self): # Check to Make sure fetch has been ran if not hasattr(self, "releases") or not hasattr(self, "release_data") or not hasattr(self, "release_url_data"): raise Exception("fetch and build must be called prior to running download") # @@@ Make a Custom Exception # Check to Make sure build has been ran if not hasattr(self, "data"): raise Exception("build must be called prior to running download") # @@@ Make a Custom Exception if not self.stored: raise Exception("package must be stored prior to downloading") # @@@ Make a Custom Exception pypi_pages = self.verify_and_sync_pages() for data in self.data.values(): try: # if pypi_pages.get("has_sig"): # simple_html = lxml.html.fromstring(pypi_pages["simple"]) # simple_html.make_links_absolute(urlparse.urljoin(SIMPLE_URL, data["package"]) + "/") # verified_md5_hashes = {} # for link in simple_html.iterlinks(): # m = _md5_re.search(link[2]) # if m:<|fim▁hole|> package = Package.objects.get(name=data["package"]) release = Release.objects.filter(package=package, version=data["version"]).select_for_update() for release_file in ReleaseFile.objects.filter(release=release, filename__in=[x["filename"] for x in data["files"]]).select_for_update(): file_data = [x for x in data["files"] if x["filename"] == release_file.filename][0] datastore_key = "crate:pypi:download:%(url)s" % {"url": file_data["file"]} stored_file_data = self.datastore.hgetall(datastore_key) headers = None if stored_file_data and self.skip_modified: # Stored data exists for this file if release_file.file: try: release_file.file.read() except IOError: pass else: # We already have a file if stored_file_data["md5"].lower() == file_data["digests"]["md5"].lower(): # The supposed MD5 from PyPI matches our local headers = { "If-Modified-Since": stored_file_data["modified"], } resp = requests.get(file_data["file"], headers=headers, prefetch=True) if resp.status_code == 304: logger.info("[DOWNLOAD] skipping %(filename)s because it has not been modified" % {"filename": release_file.filename}) return logger.info("[DOWNLOAD] downloading %(filename)s" % {"filename": release_file.filename}) resp.raise_for_status() # Make sure the MD5 of the file we receive matched what we were told it is if hashlib.md5(resp.content).hexdigest().lower() != file_data["digests"]["md5"].lower(): raise PackageHashMismatch("%s does not match %s for %s %s" % ( hashlib.md5(resp.content).hexdigest().lower(), file_data["digests"]["md5"].lower(), file_data["type"], file_data["filename"], )) release_file.digest = "$".join(["sha256", hashlib.sha256(resp.content).hexdigest().lower()]) release_file.full_clean() release_file.file.save(file_data["filename"], ContentFile(resp.content), save=False) release_file.save() Event.objects.create( package=release_file.release.package.name, version=release_file.release.version, action=Event.ACTIONS.file_add, data={ "filename": release_file.filename, "digest": release_file.digest, "uri": release_file.get_absolute_url(), } ) # Store data relating to this file (if modified etc) stored_file_data = { "md5": file_data["digests"]["md5"].lower(), "modified": resp.headers.get("Last-Modified"), } if resp.headers.get("Last-Modified"): self.datastore.hmset(datastore_key, { "md5": file_data["digests"]["md5"].lower(), "modified": resp.headers["Last-Modified"], }) # Set a year expire on the key so that stale entries disappear self.datastore.expire(datastore_key, 31556926) else: self.datastore.delete(datastore_key) except requests.HTTPError: logger.exception("[DOWNLOAD ERROR]") def get_releases(self): if self.version is None: releases = self.pypi.package_releases(self.name, True) else: releases = [self.version] logger.debug("[RELEASES] %s%s [%s]" % (self.name, " %s" % self.version if self.version else "", ", ".join(releases))) return releases def get_release_data(self): release_data = [] for release in self.releases: data = self.pypi.release_data(self.name, release) logger.debug("[RELEASE DATA] %s %s" % (self.name, release)) release_data.append([release, data]) return dict(release_data) def get_release_urls(self): release_url_data = [] for release in self.releases: data = self.pypi.release_urls(self.name, release) logger.info("[RELEASE URL] %s %s" % (self.name, release)) logger.debug("[RELEASE URL DATA] %s %s %s" % (self.name, release, data)) release_url_data.append([release, data]) return dict(release_url_data) def verify_and_sync_pages(self): # Get the Server Key for PyPI if self.datastore.get(SERVERKEY_KEY): key = load_key(self.datastore.get(SERVERKEY_KEY)) else: serverkey = requests.get(SERVERKEY_URL, prefetch=True) key = load_key(serverkey.content) self.datastore.set(SERVERKEY_KEY, serverkey.content) try: # Download the "simple" page from PyPI for this package simple = requests.get(urlparse.urljoin(SIMPLE_URL, urllib.quote(self.name.encode("utf-8"))), prefetch=True) simple.raise_for_status() except requests.HTTPError: if simple.status_code == 404: return {"has_sig": False} raise except ValueError: logger.exception("Got a ValueError from downloading the Simple page") return {"has_sig": False} try: # Download the "serversig" page from PyPI for this package serversig = requests.get(urlparse.urljoin(SERVERSIG_URL, urllib.quote(self.name.encode("utf-8"))), prefetch=True) serversig.raise_for_status() except requests.HTTPError: if serversig.status_code == 404: return {"has_sig": False} raise try: if not verify(key, simple.content, serversig.content): pass # raise Exception("Simple API page does not match serversig") # @@@ This Should be Custom Exception except (UnicodeDecodeError, UnicodeEncodeError, ValueError, AssertionError): logger.exception("Exception trying to verify %s" % self.name) # @@@ Figure out a better way to handle this try: package = Package.objects.get(normalized_name=re.sub('[^A-Za-z0-9.]+', '-', self.name).lower()) except Package.DoesNotExist: logger.exception("Error Trying To Verify %s (Querying Package)" % self.name) return simple_mirror, c = PyPIMirrorPage.objects.get_or_create(package=package, defaults={"content": simple.content}) if not c and simple_mirror.content != simple.content: simple_mirror.content = simple.content simple_mirror.save() serversig_mirror, c = PyPIServerSigPage.objects.get_or_create(package=package, defaults={"content": serversig.content.encode("base64")}) serversig_mirror.content = base64.b64encode(serversig.content) serversig_mirror.save() return { "simple": simple.content, "serversig": serversig.content, "has_sig": True, }<|fim▁end|>
# url, md5_hash = m.groups() # verified_md5_hashes[url] = md5_hash
<|file_name|>bitcoin_hr.ts<|end_file_name|><|fim▁begin|><?xml version="1.0" ?><!DOCTYPE TS><TS language="hr" version="2.1"> <context> <name>AboutDialog</name> <message> <location filename="../forms/aboutdialog.ui" line="+14"/> <source>About EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+39"/> <source>&lt;b&gt;EvilCoin&lt;/b&gt; version</source> <translation type="unfinished"/> </message> <message> <location line="+41"/> <source>Copyright © 2009-2014 The Bitcoin developers Copyright © 2012-2014 The NovaCoin developers Copyright © 2014 The EvilCoin developers</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source> This is experimental software. Distributed under the MIT/X11 software license, see the accompanying file COPYING or http://www.opensource.org/licenses/mit-license.php. This product includes software developed by the OpenSSL Project for use in the OpenSSL Toolkit (http://www.openssl.org/) and cryptographic software written by Eric Young ([email protected]) and UPnP software written by Thomas Bernard.</source> <translation type="unfinished"/> </message> </context> <context> <name>AddressBookPage</name> <message> <location filename="../forms/addressbookpage.ui" line="+14"/> <source>Address Book</source> <translation type="unfinished"/> </message> <message> <location line="+22"/> <source>Double-click to edit address or label</source> <translation>Dvostruki klik za uređivanje adrese ili oznake</translation> </message> <message> <location line="+27"/> <source>Create a new address</source> <translation>Dodajte novu adresu</translation> </message> <message> <location line="+14"/> <source>Copy the currently selected address to the system clipboard</source> <translation>Kopiraj trenutno odabranu adresu u međuspremnik</translation> </message> <message> <location line="-11"/> <source>&amp;New Address</source> <translation type="unfinished"/> </message> <message> <location line="-46"/> <source>These are your EvilCoin addresses for receiving payments. You may want to give a different one to each sender so you can keep track of who is paying you.</source> <translation type="unfinished"/> </message> <message> <location line="+60"/> <source>&amp;Copy Address</source> <translation>&amp;Kopirati adresu</translation> </message> <message> <location line="+11"/> <source>Show &amp;QR Code</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Sign a message to prove you own a EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Sign &amp;Message</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Delete the currently selected address from the list</source> <translation type="unfinished"/> </message> <message> <location line="-14"/> <source>Verify a message to ensure it was signed with a specified EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Verify Message</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>&amp;Delete</source> <translation>&amp;Brisanje</translation> </message> <message> <location filename="../addressbookpage.cpp" line="+65"/> <source>Copy &amp;Label</source> <translation>Kopirati &amp;oznaku</translation> </message> <message> <location line="+2"/> <source>&amp;Edit</source> <translation>&amp;Izmjeniti</translation> </message> <message> <location line="+250"/> <source>Export Address Book Data</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Datoteka vrijednosti odvojenih zarezom (*. csv)</translation> </message> <message> <location line="+13"/> <source>Error exporting</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation type="unfinished"/> </message> </context> <context> <name>AddressTableModel</name> <message> <location filename="../addresstablemodel.cpp" line="+144"/> <source>Label</source> <translation>Oznaka</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Adresa</translation> </message> <message> <location line="+36"/> <source>(no label)</source> <translation>(bez oznake)</translation> </message> </context> <context> <name>AskPassphraseDialog</name> <message> <location filename="../forms/askpassphrasedialog.ui" line="+26"/> <source>Passphrase Dialog</source> <translation type="unfinished"/> </message> <message> <location line="+21"/> <source>Enter passphrase</source> <translation>Unesite lozinku</translation> </message> <message> <location line="+14"/> <source>New passphrase</source> <translation>Nova lozinka</translation> </message> <message> <location line="+14"/> <source>Repeat new passphrase</source> <translation>Ponovite novu lozinku</translation> </message> <message> <location line="+33"/> <source>Serves to disable the trivial sendmoney when OS account compromised. Provides no real security.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>For staking only</source> <translation type="unfinished"/> </message> <message> <location filename="../askpassphrasedialog.cpp" line="+35"/> <source>Enter the new passphrase to the wallet.&lt;br/&gt;Please use a passphrase of &lt;b&gt;10 or more random characters&lt;/b&gt;, or &lt;b&gt;eight or more words&lt;/b&gt;.</source> <translation>Unesite novi lozinku za novčanik. &lt;br/&gt; Molimo Vas da koristite zaporku od &lt;b&gt;10 ili više slučajnih znakova,&lt;/b&gt; ili &lt;b&gt;osam ili više riječi.&lt;/b&gt;</translation> </message> <message> <location line="+1"/> <source>Encrypt wallet</source> <translation>Šifriranje novčanika</translation> </message> <message> <location line="+7"/> <source>This operation needs your wallet passphrase to unlock the wallet.</source> <translation>Ova operacija treba lozinku vašeg novčanika kako bi se novčanik otključao.</translation> </message> <message> <location line="+5"/> <source>Unlock wallet</source> <translation>Otključaj novčanik</translation> </message> <message> <location line="+3"/> <source>This operation needs your wallet passphrase to decrypt the wallet.</source> <translation>Ova operacija treba lozinku vašeg novčanika kako bi se novčanik dešifrirao.</translation> </message> <message> <location line="+5"/> <source>Decrypt wallet</source> <translation>Dešifriranje novčanika.</translation> </message> <message> <location line="+3"/> <source>Change passphrase</source> <translation>Promjena lozinke</translation> </message> <message> <location line="+1"/> <source>Enter the old and new passphrase to the wallet.</source> <translation>Unesite staru i novu lozinku za novčanik.</translation> </message> <message> <location line="+46"/> <source>Confirm wallet encryption</source> <translation>Potvrdi šifriranje novčanika</translation> </message> <message> <location line="+1"/> <source>Warning: If you encrypt your wallet and lose your passphrase, you will &lt;b&gt;LOSE ALL OF YOUR COINS&lt;/b&gt;!</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Are you sure you wish to encrypt your wallet?</source> <translation>Jeste li sigurni da želite šifrirati svoj novčanik?</translation> </message> <message> <location line="+15"/> <source>IMPORTANT: Any previous backups you have made of your wallet file should be replaced with the newly generated, encrypted wallet file. For security reasons, previous backups of the unencrypted wallet file will become useless as soon as you start using the new, encrypted wallet.</source> <translation type="unfinished"/> </message> <message> <location line="+103"/> <location line="+24"/> <source>Warning: The Caps Lock key is on!</source> <translation>Upozorenje: Tipka Caps Lock je uključena!</translation> </message> <message> <location line="-133"/> <location line="+60"/> <source>Wallet encrypted</source> <translation>Novčanik šifriran</translation> </message> <message> <location line="-58"/> <source>EvilCoin will close now to finish the encryption process. Remember that encrypting your wallet cannot fully protect your coins from being stolen by malware infecting your computer.</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <location line="+7"/> <location line="+44"/> <location line="+6"/> <source>Wallet encryption failed</source> <translation>Šifriranje novčanika nije uspjelo</translation> </message> <message> <location line="-56"/> <source>Wallet encryption failed due to an internal error. Your wallet was not encrypted.</source> <translation>Šifriranje novčanika nije uspjelo zbog interne pogreške. Vaš novčanik nije šifriran.</translation> </message> <message> <location line="+7"/> <location line="+50"/> <source>The supplied passphrases do not match.</source> <translation>Priložene lozinke se ne podudaraju.</translation> </message> <message> <location line="-38"/> <source>Wallet unlock failed</source> <translation>Otključavanje novčanika nije uspjelo</translation> </message> <message> <location line="+1"/> <location line="+12"/> <location line="+19"/> <source>The passphrase entered for the wallet decryption was incorrect.</source> <translation>Lozinka za dešifriranje novčanika nije točna.</translation> </message> <message> <location line="-20"/> <source>Wallet decryption failed</source> <translation>Dešifriranje novčanika nije uspjelo</translation> </message> <message> <location line="+14"/> <source>Wallet passphrase was successfully changed.</source> <translation>Lozinka novčanika je uspješno promijenjena.</translation> </message> </context> <context> <name>BitcoinGUI</name> <message> <location filename="../bitcoingui.cpp" line="+282"/> <source>Sign &amp;message...</source> <translation>&amp;Potpišite poruku...</translation> </message> <message> <location line="+251"/> <source>Synchronizing with network...</source> <translation>Usklađivanje s mrežom ...</translation> </message> <message> <location line="-319"/> <source>&amp;Overview</source> <translation>&amp;Pregled</translation> </message> <message> <location line="+1"/> <source>Show general overview of wallet</source> <translation>Prikaži opći pregled novčanika</translation> </message> <message> <location line="+17"/> <source>&amp;Transactions</source> <translation>&amp;Transakcije</translation> </message> <message> <location line="+1"/> <source>Browse transaction history</source> <translation>Pretraži povijest transakcija</translation> </message> <message> <location line="+5"/> <source>&amp;Address Book</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Edit the list of stored addresses and labels</source> <translation type="unfinished"/> </message> <message> <location line="-13"/> <source>&amp;Receive coins</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Show the list of addresses for receiving payments</source> <translation type="unfinished"/> </message> <message> <location line="-7"/> <source>&amp;Send coins</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>E&amp;xit</source> <translation>&amp;Izlaz</translation> </message> <message> <location line="+1"/> <source>Quit application</source> <translation>Izlazak iz programa</translation> </message> <message> <location line="+6"/> <source>Show information about EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>About &amp;Qt</source> <translation>Više o &amp;Qt</translation> </message> <message> <location line="+1"/> <source>Show information about Qt</source> <translation>Prikaži informacije o Qt</translation> </message> <message> <location line="+2"/> <source>&amp;Options...</source> <translation>&amp;Postavke</translation> </message> <message> <location line="+4"/> <source>&amp;Encrypt Wallet...</source> <translation>&amp;Šifriraj novčanik...</translation> </message> <message> <location line="+3"/> <source>&amp;Backup Wallet...</source> <translation>&amp;Backup novčanika...</translation> </message> <message> <location line="+2"/> <source>&amp;Change Passphrase...</source> <translation>&amp;Promijena lozinke...</translation> </message> <message numerus="yes"> <location line="+259"/> <source>~%n block(s) remaining</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+6"/> <source>Downloaded %1 of %2 blocks of transaction history (%3% done).</source> <translation type="unfinished"/> </message> <message> <location line="-256"/> <source>&amp;Export...</source> <translation type="unfinished"/> </message> <message> <location line="-64"/> <source>Send coins to a EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+47"/> <source>Modify configuration options for EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>Export the data in the current tab to a file</source> <translation type="unfinished"/> </message> <message> <location line="-14"/> <source>Encrypt or decrypt wallet</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Backup wallet to another location</source> <translation>Napravite sigurnosnu kopiju novčanika na drugoj lokaciji</translation> </message> <message> <location line="+2"/> <source>Change the passphrase used for wallet encryption</source> <translation>Promijenite lozinku za šifriranje novčanika</translation> </message> <message> <location line="+10"/> <source>&amp;Debug window</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Open debugging and diagnostic console</source> <translation type="unfinished"/> </message> <message> <location line="-5"/> <source>&amp;Verify message...</source> <translation>&amp;Potvrdite poruku...</translation> </message> <message> <location line="-202"/> <source>EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Wallet</source> <translation>Novčanik</translation> </message> <message> <location line="+180"/> <source>&amp;About EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+9"/> <source>&amp;Show / Hide</source> <translation type="unfinished"/> </message> <message> <location line="+9"/> <source>Unlock wallet</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>&amp;Lock Wallet</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Lock wallet</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>&amp;File</source> <translation>&amp;Datoteka</translation> </message> <message> <location line="+8"/> <source>&amp;Settings</source> <translation>&amp;Konfiguracija</translation> </message> <message> <location line="+8"/> <source>&amp;Help</source> <translation>&amp;Pomoć</translation> </message> <message> <location line="+12"/> <source>Tabs toolbar</source> <translation>Traka kartica</translation> </message> <message> <location line="+8"/> <source>Actions toolbar</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <location line="+9"/> <source>[testnet]</source> <translation>[testnet]</translation> </message> <message> <location line="+0"/> <location line="+60"/> <source>EvilCoin client</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+75"/> <source>%n active connection(s) to EvilCoin network</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+40"/> <source>Downloaded %1 blocks of transaction history.</source> <translation type="unfinished"/> </message> <message> <location line="+413"/> <source>Staking.&lt;br&gt;Your weight is %1&lt;br&gt;Network weight is %2&lt;br&gt;Expected time to earn reward is %3</source> <translation type="unfinished"/> </message> <message> <location line="+6"/> <source>Not staking because wallet is locked</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because wallet is offline</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because wallet is syncing</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Not staking because you don&apos;t have mature coins</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="-403"/> <source>%n second(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="-312"/> <source>About EvilCoin card</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Show information about EvilCoin card</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>&amp;Unlock Wallet...</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+297"/> <source>%n minute(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n hour(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n day(s) ago</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+6"/> <source>Up to date</source> <translation>Ažurno</translation> </message> <message> <location line="+7"/> <source>Catching up...</source> <translation>Ažuriranje...</translation> </message> <message> <location line="+10"/> <source>Last received block was generated %1.</source> <translation type="unfinished"/> </message> <message> <location line="+59"/> <source>This transaction is over the size limit. You can still send it for a fee of %1, which goes to the nodes that process your transaction and helps to support the network. Do you want to pay the fee?</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Confirm transaction fee</source> <translation type="unfinished"/> </message> <message> <location line="+27"/> <source>Sent transaction</source> <translation>Poslana transakcija</translation> </message> <message> <location line="+1"/> <source>Incoming transaction</source> <translation>Dolazna transakcija</translation> </message> <message> <location line="+1"/> <source>Date: %1 Amount: %2 Type: %3 Address: %4 </source> <translation>Datum:%1 Iznos:%2 Tip:%3 Adresa:%4 </translation> </message> <message> <location line="+100"/> <location line="+15"/> <source>URI handling</source> <translation type="unfinished"/> </message> <message> <location line="-15"/> <location line="+15"/> <source>URI can not be parsed! This can be caused by an invalid EvilCoin address or malformed URI parameters.</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;unlocked&lt;/b&gt;</source> <translation>Novčanik je &lt;b&gt;šifriran&lt;/b&gt; i trenutno &lt;b&gt;otključan&lt;/b&gt;</translation> </message> <message> <location line="+10"/> <source>Wallet is &lt;b&gt;encrypted&lt;/b&gt; and currently &lt;b&gt;locked&lt;/b&gt;</source> <translation>Novčanik je &lt;b&gt;šifriran&lt;/b&gt; i trenutno &lt;b&gt;zaključan&lt;/b&gt;</translation> </message> <message> <location line="+25"/> <source>Backup Wallet</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Wallet Data (*.dat)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Backup Failed</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>There was an error trying to save the wallet data to the new location.</source> <translation type="unfinished"/> </message> <message numerus="yes"> <location line="+76"/> <source>%n second(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n minute(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n hour(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message numerus="yes"> <location line="+4"/> <source>%n day(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+18"/> <source>Not staking</source> <translation type="unfinished"/> </message> <message> <location filename="../bitcoin.cpp" line="+109"/> <source>A fatal error occurred. EvilCoin can no longer continue safely and will quit.</source> <translation type="unfinished"/> </message> </context> <context> <name>ClientModel</name> <message> <location filename="../clientmodel.cpp" line="+90"/> <source>Network Alert</source> <translation type="unfinished"/> </message> </context> <context> <name>CoinControlDialog</name> <message> <location filename="../forms/coincontroldialog.ui" line="+14"/> <source>Coin Control</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Quantity:</source> <translation type="unfinished"/> </message> <message> <location line="+32"/> <source>Bytes:</source> <translation type="unfinished"/> </message> <message> <location line="+48"/> <source>Amount:</source> <translation>Iznos:</translation> </message> <message> <location line="+32"/> <source>Priority:</source> <translation type="unfinished"/> </message> <message> <location line="+48"/> <source>Fee:</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>Low Output:</source> <translation type="unfinished"/> </message> <message> <location filename="../coincontroldialog.cpp" line="+551"/> <source>no</source> <translation type="unfinished"/> </message> <message> <location filename="../forms/coincontroldialog.ui" line="+51"/> <source>After Fee:</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>Change:</source> <translation type="unfinished"/> </message> <message> <location line="+69"/> <source>(un)select all</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>Tree mode</source> <translation type="unfinished"/> </message> <message> <location line="+16"/> <source>List mode</source> <translation type="unfinished"/> </message> <message> <location line="+45"/> <source>Amount</source> <translation>Iznos</translation> </message> <message> <location line="+5"/> <source>Label</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Address</source> <translation>Adresa</translation> </message> <message> <location line="+5"/> <source>Date</source> <translation>Datum</translation> </message> <message> <location line="+5"/> <source>Confirmations</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Confirmed</source> <translation>Potvrđeno</translation> </message> <message> <location line="+5"/> <source>Priority</source> <translation type="unfinished"/> </message> <message> <location filename="../coincontroldialog.cpp" line="-515"/> <source>Copy address</source> <translation>Kopirati adresu</translation> </message> <message> <location line="+1"/> <source>Copy label</source> <translation>Kopirati oznaku</translation> </message> <message> <location line="+1"/> <location line="+26"/> <source>Copy amount</source> <translation>Kopiraj iznos</translation> </message> <message> <location line="-25"/> <source>Copy transaction ID</source> <translation type="unfinished"/> </message> <message> <location line="+24"/> <source>Copy quantity</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Copy fee</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy after fee</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy bytes</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy priority</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy low output</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy change</source> <translation type="unfinished"/> </message> <message> <location line="+317"/> <source>highest</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>high</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>medium-high</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>medium</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>low-medium</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>low</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>lowest</source> <translation type="unfinished"/> </message> <message> <location line="+155"/> <source>DUST</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>yes</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>This label turns red, if the transaction size is bigger than 10000 bytes. This means a fee of at least %1 per kb is required. Can vary +/- 1 Byte per input.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Transactions with higher priority get more likely into a block. This label turns red, if the priority is smaller than &quot;medium&quot;. This means a fee of at least %1 per kb is required.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>This label turns red, if any recipient receives an amount smaller than %1. This means a fee of at least %2 is required. Amounts below 0.546 times the minimum relay fee are shown as DUST.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>This label turns red, if the change is smaller than %1. This means a fee of at least %2 is required.</source> <translation type="unfinished"/> </message> <message> <location line="+37"/> <location line="+66"/> <source>(no label)</source> <translation>(bez oznake)</translation> </message> <message> <location line="-9"/> <source>change from %1 (%2)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>(change)</source> <translation type="unfinished"/> </message> </context> <context> <name>EditAddressDialog</name> <message> <location filename="../forms/editaddressdialog.ui" line="+14"/> <source>Edit Address</source> <translation>Izmjeni adresu</translation> </message> <message> <location line="+11"/> <source>&amp;Label</source> <translation>&amp;Oznaka</translation> </message> <message> <location line="+10"/> <source>The label associated with this address book entry</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>&amp;Address</source> <translation>&amp;Adresa</translation> </message> <message> <location line="+10"/> <source>The address associated with this address book entry. This can only be modified for sending addresses.</source> <translation type="unfinished"/> </message> <message> <location filename="../editaddressdialog.cpp" line="+20"/> <source>New receiving address</source> <translation>Nova adresa za primanje</translation> </message> <message> <location line="+4"/> <source>New sending address</source> <translation>Nova adresa za slanje</translation> </message> <message> <location line="+3"/> <source>Edit receiving address</source> <translation>Uredi adresu za primanje</translation> </message> <message> <location line="+4"/> <source>Edit sending address</source> <translation>Uredi adresu za slanje</translation> </message> <message> <location line="+76"/> <source>The entered address &quot;%1&quot; is already in the address book.</source> <translation>Upisana adresa &quot;%1&quot; je već u adresaru.</translation> </message> <message> <location line="-5"/> <source>The entered address &quot;%1&quot; is not a valid EvilCoin address.</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Could not unlock wallet.</source> <translation>Ne mogu otključati novčanik.</translation> </message> <message> <location line="+5"/> <source>New key generation failed.</source> <translation>Stvaranje novog ključa nije uspjelo.</translation> </message> </context> <context> <name>GUIUtil::HelpMessageBox</name> <message> <location filename="../guiutil.cpp" line="+420"/> <location line="+12"/> <source>EvilCoin-Qt</source> <translation type="unfinished"/> </message> <message> <location line="-12"/> <source>version</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Usage:</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>command-line options</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>UI options</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Set language, for example &quot;de_DE&quot; (default: system locale)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Start minimized</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Show splash screen on startup (default: 1)</source> <translation type="unfinished"/> </message> </context> <context> <name>OptionsDialog</name> <message> <location filename="../forms/optionsdialog.ui" line="+14"/> <source>Options</source> <translation>Postavke</translation> </message> <message> <location line="+16"/> <source>&amp;Main</source> <translation>&amp;Glavno</translation> </message> <message> <location line="+6"/> <source>Optional transaction fee per kB that helps make sure your transactions are processed quickly. Most transactions are 1 kB. Fee 0.01 recommended.</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Pay transaction &amp;fee</source> <translation>Plati &amp;naknadu za transakciju</translation> </message> <message> <location line="+31"/> <source>Reserved amount does not participate in staking and is therefore spendable at any time.</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Reserve</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Automatically start EvilCoin after logging in to the system.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Start EvilCoin on system login</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Detach block and address databases at shutdown. This means they can be moved to another data directory, but it slows down shutdown. The wallet is always detached.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Detach databases at shutdown</source> <translation type="unfinished"/> </message> <message> <location line="+21"/> <source>&amp;Network</source> <translation>&amp;Mreža</translation> </message> <message> <location line="+6"/> <source>Automatically open the EvilCoin client port on the router. This only works when your router supports UPnP and it is enabled.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Map port using &amp;UPnP</source> <translation>Mapiraj port koristeći &amp;UPnP</translation> </message> <message> <location line="+7"/> <source>Connect to the EvilCoin network through a SOCKS proxy (e.g. when connecting through Tor).</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Connect through SOCKS proxy:</source> <translation type="unfinished"/> </message> <message> <location line="+9"/> <source>Proxy &amp;IP:</source> <translation>Proxy &amp;IP:</translation> </message> <message> <location line="+19"/> <source>IP address of the proxy (e.g. 127.0.0.1)</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>&amp;Port:</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>Port of the proxy (e.g. 9050)</source> <translation>Port od proxy-a (npr. 9050)</translation> </message> <message> <location line="+7"/> <source>SOCKS &amp;Version:</source> <translation>SOCKS &amp;Verzija:</translation> </message> <message> <location line="+13"/> <source>SOCKS version of the proxy (e.g. 5)</source> <translation type="unfinished"/> </message> <message> <location line="+36"/> <source>&amp;Window</source> <translation>&amp;Prozor</translation> </message> <message> <location line="+6"/> <source>Show only a tray icon after minimizing the window.</source> <translation>Prikaži samo ikonu u sistemskoj traci nakon minimiziranja prozora</translation> </message> <message> <location line="+3"/> <source>&amp;Minimize to the tray instead of the taskbar</source> <translation>&amp;Minimiziraj u sistemsku traku umjesto u traku programa</translation> </message> <message> <location line="+7"/> <source>Minimize instead of exit the application when the window is closed. When this option is enabled, the application will be closed only after selecting Quit in the menu.</source> <translation>Minimizirati umjesto izaći iz aplikacije kada je prozor zatvoren. Kada je ova opcija omogućena, aplikacija će biti zatvorena tek nakon odabira Izlaz u izborniku.</translation> </message> <message> <location line="+3"/> <source>M&amp;inimize on close</source> <translation>M&amp;inimiziraj kod zatvaranja</translation> </message> <message> <location line="+21"/> <source>&amp;Display</source> <translation>&amp;Prikaz</translation> </message> <message> <location line="+8"/> <source>User Interface &amp;language:</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>The user interface language can be set here. This setting will take effect after restarting EvilCoin.</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>&amp;Unit to show amounts in:</source> <translation>&amp;Jedinica za prikazivanje iznosa:</translation> </message> <message> <location line="+13"/> <source>Choose the default subdivision unit to show in the interface and when sending coins.</source> <translation>Izaberite željeni najmanji dio bitcoina koji će biti prikazan u sučelju i koji će se koristiti za plaćanje.</translation> </message> <message> <location line="+9"/> <source>Whether to show EvilCoin addresses in the transaction list or not.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Display addresses in transaction list</source> <translation>&amp;Prikaži adrese u popisu transakcija</translation> </message> <message> <location line="+7"/> <source>Whether to show coin control features or not.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Display coin &amp;control features (experts only!)</source> <translation type="unfinished"/> </message> <message> <location line="+71"/> <source>&amp;OK</source> <translation>&amp;U redu</translation> </message> <message> <location line="+7"/> <source>&amp;Cancel</source> <translation>&amp;Odustani</translation> </message> <message> <location line="+10"/> <source>&amp;Apply</source> <translation type="unfinished"/> </message> <message> <location filename="../optionsdialog.cpp" line="+55"/> <source>default</source> <translation>standardne vrijednosti</translation> </message> <message> <location line="+149"/> <location line="+9"/> <source>Warning</source> <translation type="unfinished"/> </message> <message> <location line="-9"/> <location line="+9"/> <source>This setting will take effect after restarting EvilCoin.</source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>The supplied proxy address is invalid.</source> <translation type="unfinished"/> </message> </context> <context> <name>OverviewPage</name> <message> <location filename="../forms/overviewpage.ui" line="+14"/> <source>Form</source> <translation>Oblik</translation> </message> <message> <location line="+33"/> <location line="+231"/> <source>The displayed information may be out of date. Your wallet automatically synchronizes with the EvilCoin network after a connection is established, but this process has not completed yet.</source> <translation type="unfinished"/> </message> <message> <location line="-160"/> <source>Stake:</source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>Unconfirmed:</source> <translation type="unfinished"/> </message> <message> <location line="-107"/> <source>Wallet</source> <translation>Novčanik</translation> </message> <message> <location line="+49"/> <source>Spendable:</source> <translation type="unfinished"/> </message> <message> <location line="+16"/> <source>Your current spendable balance</source> <translation type="unfinished"/> </message> <message> <location line="+71"/> <source>Immature:</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>Mined balance that has not yet matured</source> <translation type="unfinished"/> </message> <message> <location line="+20"/> <source>Total:</source> <translation>Ukupno:</translation> </message> <message> <location line="+16"/> <source>Your current total balance</source> <translation type="unfinished"/> </message> <message> <location line="+46"/> <source>&lt;b&gt;Recent transactions&lt;/b&gt;</source> <translation>&lt;b&gt;Nedavne transakcije&lt;/b&gt;</translation> </message> <message> <location line="-108"/> <source>Total of transactions that have yet to be confirmed, and do not yet count toward the current balance</source> <translation type="unfinished"/> </message> <message> <location line="-29"/> <source>Total of coins that was staked, and do not yet count toward the current balance</source> <translation type="unfinished"/> </message> <message> <location filename="../overviewpage.cpp" line="+113"/> <location line="+1"/> <source>out of sync</source> <translation type="unfinished"/> </message> </context> <context> <name>QRCodeDialog</name> <message> <location filename="../forms/qrcodedialog.ui" line="+14"/> <source>QR Code Dialog</source> <translation type="unfinished"/> </message> <message> <location line="+59"/> <source>Request Payment</source> <translation type="unfinished"/> </message> <message> <location line="+56"/> <source>Amount:</source> <translation type="unfinished"/> </message> <message> <location line="-44"/> <source>Label:</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>Message:</source> <translation type="unfinished"/> </message> <message> <location line="+71"/> <source>&amp;Save As...</source> <translation type="unfinished"/> </message> <message> <location filename="../qrcodedialog.cpp" line="+62"/> <source>Error encoding URI into QR Code.</source> <translation type="unfinished"/> </message> <message> <location line="+40"/> <source>The entered amount is invalid, please check.</source> <translation type="unfinished"/> </message> <message> <location line="+23"/> <source>Resulting URI too long, try to reduce the text for label / message.</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Save QR Code</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>PNG Images (*.png)</source> <translation type="unfinished"/> </message> </context> <context> <name>RPCConsole</name> <message> <location filename="../forms/rpcconsole.ui" line="+46"/> <source>Client name</source> <translation>Ime klijenta</translation> </message> <message> <location line="+10"/> <location line="+23"/> <location line="+26"/> <location line="+23"/> <location line="+23"/> <location line="+36"/> <location line="+53"/> <location line="+23"/> <location line="+23"/> <location filename="../rpcconsole.cpp" line="+348"/> <source>N/A</source> <translation>N/A</translation> </message> <message> <location line="-217"/> <source>Client version</source> <translation>Verzija klijenta</translation> </message> <message> <location line="-45"/> <source>&amp;Information</source> <translation>&amp;Informacija</translation> </message> <message> <location line="+68"/> <source>Using OpenSSL version</source> <translation>Koristim OpenSSL verziju</translation> </message> <message> <location line="+49"/> <source>Startup time</source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>Network</source> <translation>Mreža</translation> </message> <message> <location line="+7"/> <source>Number of connections</source> <translation>Broj konekcija</translation> </message> <message> <location line="+23"/> <source>On testnet</source> <translation type="unfinished"/> </message> <message> <location line="+23"/> <source>Block chain</source> <translation>Lanac blokova</translation> </message> <message> <location line="+7"/> <source>Current number of blocks</source> <translation>Trenutni broj blokova</translation> </message> <message> <location line="+23"/> <source>Estimated total blocks</source> <translation>Procjenjeni ukupni broj blokova</translation> </message> <message> <location line="+23"/> <source>Last block time</source> <translation>Posljednje vrijeme bloka</translation> </message> <message> <location line="+52"/> <source>&amp;Open</source> <translation>&amp;Otvori</translation> </message> <message> <location line="+16"/> <source>Command-line options</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Show the EvilCoin-Qt help message to get a list with possible EvilCoin command-line options.</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>&amp;Show</source> <translation type="unfinished"/> </message> <message> <location line="+24"/> <source>&amp;Console</source> <translation>&amp;Konzola</translation> </message> <message> <location line="-260"/> <source>Build date</source> <translation type="unfinished"/> </message> <message> <location line="-104"/> <source>EvilCoin - Debug window</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>EvilCoin Core</source> <translation type="unfinished"/> </message> <message> <location line="+279"/> <source>Debug log file</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Open the EvilCoin debug log file from the current data directory. This can take a few seconds for large log files.</source> <translation type="unfinished"/> </message> <message> <location line="+102"/> <source>Clear console</source> <translation>Očisti konzolu</translation> </message> <message> <location filename="../rpcconsole.cpp" line="-33"/> <source>Welcome to the EvilCoin RPC console.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Use up and down arrows to navigate history, and &lt;b&gt;Ctrl-L&lt;/b&gt; to clear screen.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Type &lt;b&gt;help&lt;/b&gt; for an overview of available commands.</source> <translation type="unfinished"/> </message> </context> <context> <name>SendCoinsDialog</name> <message> <location filename="../forms/sendcoinsdialog.ui" line="+14"/> <location filename="../sendcoinsdialog.cpp" line="+182"/> <location line="+5"/> <location line="+5"/> <location line="+5"/> <location line="+6"/> <location line="+5"/> <location line="+5"/> <source>Send Coins</source> <translation>Slanje novca</translation> </message> <message> <location line="+76"/> <source>Coin Control Features</source> <translation type="unfinished"/> </message> <message> <location line="+20"/> <source>Inputs...</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>automatically selected</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>Insufficient funds!</source> <translation type="unfinished"/> </message> <message> <location line="+77"/> <source>Quantity:</source> <translation type="unfinished"/> </message> <message> <location line="+22"/> <location line="+35"/> <source>0</source> <translation type="unfinished"/> </message> <message> <location line="-19"/> <source>Bytes:</source> <translation type="unfinished"/> </message> <message> <location line="+51"/> <source>Amount:</source> <translation>Iznos:</translation> </message> <message> <location line="+22"/> <location line="+86"/> <location line="+86"/> <location line="+32"/> <source>0.00 hack</source> <translation type="unfinished"/> </message> <message> <location line="-191"/> <source>Priority:</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>medium</source> <translation type="unfinished"/> </message> <message> <location line="+32"/> <source>Fee:</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>Low Output:</source> <translation type="unfinished"/> </message> <message> <location line="+19"/> <source>no</source> <translation type="unfinished"/> </message> <message> <location line="+32"/> <source>After Fee:</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>Change</source> <translation type="unfinished"/> </message> <message> <location line="+50"/> <source>custom change address</source> <translation type="unfinished"/> </message> <message> <location line="+106"/> <source>Send to multiple recipients at once</source> <translation>Pošalji k nekoliko primatelja odjednom</translation> </message> <message> <location line="+3"/> <source>Add &amp;Recipient</source> <translation>&amp;Dodaj primatelja</translation> </message> <message> <location line="+20"/> <source>Remove all transaction fields</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Clear &amp;All</source> <translation>Obriši &amp;sve</translation> </message> <message> <location line="+28"/> <source>Balance:</source> <translation>Stanje:</translation> </message> <message> <location line="+16"/> <source>123.456 hack</source> <translation type="unfinished"/> </message> <message> <location line="+31"/> <source>Confirm the send action</source> <translation>Potvrdi akciju slanja</translation> </message> <message> <location line="+3"/> <source>S&amp;end</source> <translation>&amp;Pošalji</translation> </message> <message> <location filename="../sendcoinsdialog.cpp" line="-173"/> <source>Enter a EvilCoin address (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>Copy quantity</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy amount</source> <translation>Kopiraj iznos</translation> </message> <message> <location line="+1"/> <source>Copy fee</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy after fee</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy bytes</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy priority</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy low output</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Copy change</source> <translation type="unfinished"/> </message> <message> <location line="+86"/> <source>&lt;b&gt;%1&lt;/b&gt; to %2 (%3)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Confirm send coins</source> <translation>Potvrdi slanje novca</translation> </message> <message> <location line="+1"/> <source>Are you sure you want to send %1?</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source> and </source> <translation type="unfinished"/> </message> <message> <location line="+29"/> <source>The recipient address is not valid, please recheck.</source> <translation>Adresa primatelja je nevaljala, molimo provjerite je ponovo.</translation> </message> <message> <location line="+5"/> <source>The amount to pay must be larger than 0.</source> <translation>Iznos mora biti veći od 0.</translation> </message> <message> <location line="+5"/> <source>The amount exceeds your balance.</source> <translation>Iznos je veći od stanja računa.</translation> </message> <message> <location line="+5"/> <source>The total exceeds your balance when the %1 transaction fee is included.</source> <translation>Iznos je veći od stanja računa kad se doda naknada za transakcije od %1.</translation> </message> <message> <location line="+6"/> <source>Duplicate address found, can only send to each address once per send operation.</source> <translation>Pronašli smo adresu koja se ponavlja. U svakom plaćanju program može svaku adresu koristiti samo jedanput.</translation> </message> <message> <location line="+5"/> <source>Error: Transaction creation failed.</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Error: The transaction was rejected. This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation type="unfinished"/> </message> <message> <location line="+251"/> <source>WARNING: Invalid EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <source>(no label)</source> <translation>(bez oznake)</translation> </message> <message> <location line="+4"/> <source>WARNING: unknown change address</source> <translation type="unfinished"/> </message> </context> <context> <name>SendCoinsEntry</name> <message> <location filename="../forms/sendcoinsentry.ui" line="+14"/> <source>Form</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>A&amp;mount:</source> <translation>&amp;Iznos:</translation> </message> <message> <location line="+13"/> <source>Pay &amp;To:</source> <translation>&amp;Primatelj plaćanja:</translation> </message> <message> <location line="+24"/> <location filename="../sendcoinsentry.cpp" line="+25"/> <source>Enter a label for this address to add it to your address book</source> <translation>Unesite oznaku za ovu adresu kako bi ju dodali u vaš adresar</translation> </message> <message> <location line="+9"/> <source>&amp;Label:</source> <translation>&amp;Oznaka:</translation> </message> <message> <location line="+18"/> <source>The address to send the payment to (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Choose address from address book</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="+7"/> <source>Paste address from clipboard</source> <translation>Zalijepi adresu iz međuspremnika</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+7"/> <source>Remove this recipient</source> <translation type="unfinished"/> </message> <message> <location filename="../sendcoinsentry.cpp" line="+1"/> <source>Enter a EvilCoin address (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> </context> <context> <name>SignVerifyMessageDialog</name> <message> <location filename="../forms/signverifymessagedialog.ui" line="+14"/> <source>Signatures - Sign / Verify a Message</source> <translation type="unfinished"/> </message> <message> <location line="+13"/> <location line="+124"/> <source>&amp;Sign Message</source> <translation>&amp;Potpišite poruku</translation> </message> <message> <location line="-118"/> <source>You can sign messages with your addresses to prove you own them. Be careful not to sign anything vague, as phishing attacks may try to trick you into signing your identity over to them. Only sign fully-detailed statements you agree to.</source> <translation>Možete potpisati poruke sa svojom adresom kako bi dokazali da ih posjedujete. Budite oprezni da ne potpisujete ništa mutno, jer bi vas phishing napadi mogli na prevaru natjerati da prepišete svoj identitet njima. Potpisujte samo detaljno objašnjene izjave sa kojima se slažete.</translation> </message> <message> <location line="+18"/> <source>The address to sign the message with (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> <message> <location line="+10"/> <location line="+203"/> <source>Choose an address from the address book</source> <translation type="unfinished"/> </message> <message> <location line="-193"/> <location line="+203"/> <source>Alt+A</source> <translation>Alt+A</translation> </message> <message> <location line="-193"/> <source>Paste address from clipboard</source> <translation>Zalijepi adresu iz međuspremnika</translation> </message> <message> <location line="+10"/> <source>Alt+P</source> <translation>Alt+P</translation> </message> <message> <location line="+12"/> <source>Enter the message you want to sign here</source> <translation>Upišite poruku koju želite potpisati ovdje</translation> </message> <message> <location line="+24"/> <source>Copy the current signature to the system clipboard</source> <translation type="unfinished"/> </message> <message> <location line="+21"/> <source>Sign the message to prove you own this EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+17"/> <source>Reset all sign message fields</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <location line="+146"/> <source>Clear &amp;All</source> <translation>Obriši &amp;sve</translation> </message> <message> <location line="-87"/> <location line="+70"/> <source>&amp;Verify Message</source> <translation>&amp;Potvrdite poruku</translation> </message> <message> <location line="-64"/> <source>Enter the signing address, message (ensure you copy line breaks, spaces, tabs, etc. exactly) and signature below to verify the message. Be careful not to read more into the signature than what is in the signed message itself, to avoid being tricked by a man-in-the-middle attack.</source> <translation type="unfinished"/> </message> <message> <location line="+21"/> <source>The address the message was signed with (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> <message> <location line="+40"/> <source>Verify the message to ensure it was signed with the specified EvilCoin address</source> <translation type="unfinished"/> </message> <message> <location line="+17"/> <source>Reset all verify message fields</source> <translation type="unfinished"/> </message> <message> <location filename="../signverifymessagedialog.cpp" line="+27"/> <location line="+3"/> <source>Enter a EvilCoin address (e.g. EvilCoinfwYhBmGXcFP2Po1NpRUEiK8km2)</source> <translation type="unfinished"/> </message> <message> <location line="-2"/> <source>Click &quot;Sign Message&quot; to generate signature</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Enter EvilCoin signature</source> <translation type="unfinished"/> </message> <message> <location line="+82"/> <location line="+81"/> <source>The entered address is invalid.</source> <translation type="unfinished"/> </message> <message> <location line="-81"/> <location line="+8"/> <location line="+73"/> <location line="+8"/> <source>Please check the address and try again.</source> <translation type="unfinished"/> </message> <message> <location line="-81"/> <location line="+81"/> <source>The entered address does not refer to a key.</source> <translation type="unfinished"/> </message> <message> <location line="-73"/> <source>Wallet unlock was cancelled.</source> <translation>Otključavanje novčanika je otkazano.</translation> </message> <message> <location line="+8"/> <source>Private key for the entered address is not available.</source> <translation type="unfinished"/> </message> <message> <location line="+12"/> <source>Message signing failed.</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Message signed.</source> <translation>Poruka je potpisana.</translation> </message> <message> <location line="+59"/> <source>The signature could not be decoded.</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <location line="+13"/> <source>Please check the signature and try again.</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>The signature did not match the message digest.</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Message verification failed.</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Message verified.</source> <translation type="unfinished"/> </message> </context> <context> <name>TransactionDesc</name> <message> <location filename="../transactiondesc.cpp" line="+19"/> <source>Open until %1</source> <translation>Otvoren do %1</translation> </message> <message numerus="yes"> <location line="-2"/> <source>Open for %n block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+8"/> <source>conflicted</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>%1/offline</source> <translation>%1 nije dostupan</translation> </message> <message> <location line="+2"/> <source>%1/unconfirmed</source> <translation>%1/nepotvrđeno</translation> </message> <message> <location line="+2"/> <source>%1 confirmations</source> <translation>%1 potvrda</translation> </message> <message> <location line="+18"/> <source>Status</source> <translation>Status</translation> </message> <message numerus="yes"> <location line="+7"/> <source>, broadcast through %n node(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+4"/> <source>Date</source> <translation>Datum</translation> </message> <message> <location line="+7"/> <source>Source</source> <translation>Izvor</translation> </message> <message> <location line="+0"/> <source>Generated</source> <translation>Generiran</translation> </message> <message> <location line="+5"/> <location line="+17"/> <source>From</source> <translation>Od</translation> </message> <message> <location line="+1"/> <location line="+22"/> <location line="+58"/> <source>To</source> <translation>Za</translation> </message> <message> <location line="-77"/> <location line="+2"/> <source>own address</source> <translation>vlastita adresa</translation> </message> <message> <location line="-2"/> <source>label</source> <translation>oznaka</translation> </message> <message> <location line="+37"/> <location line="+12"/> <location line="+45"/> <location line="+17"/> <location line="+30"/> <source>Credit</source> <translation>Uplaćeno</translation> </message> <message numerus="yes"> <location line="-102"/> <source>matures in %n more block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+2"/> <source>not accepted</source> <translation>Nije prihvaćeno</translation> </message> <message> <location line="+44"/> <location line="+8"/> <location line="+15"/> <location line="+30"/> <source>Debit</source> <translation>Zaduženje</translation> </message> <message> <location line="-39"/> <source>Transaction fee</source> <translation>Naknada za transakciju</translation> </message> <message> <location line="+16"/> <source>Net amount</source> <translation>Neto iznos</translation> </message> <message> <location line="+6"/> <source>Message</source> <translation>Poruka</translation> </message> <message> <location line="+2"/> <source>Comment</source> <translation>Komentar</translation> </message> <message> <location line="+2"/> <source>Transaction ID</source> <translation>ID transakcije</translation> </message> <message> <location line="+3"/> <source>Generated coins must mature 510 blocks before they can be spent. When you generated this block, it was broadcast to the network to be added to the block chain. If it fails to get into the chain, its state will change to &quot;not accepted&quot; and it won&apos;t be spendable. This may occasionally happen if another node generates a block within a few seconds of yours.</source> <translation type="unfinished"/> </message> <message> <location line="+7"/> <source>Debug information</source> <translation type="unfinished"/> </message> <message> <location line="+8"/> <source>Transaction</source> <translation>Transakcija</translation> </message> <message> <location line="+5"/> <source>Inputs</source> <translation>Unosi</translation> </message> <message> <location line="+23"/> <source>Amount</source> <translation>Iznos</translation> </message> <message> <location line="+1"/> <source>true</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>false</source> <translation type="unfinished"/> </message> <message> <location line="-211"/> <source>, has not been successfully broadcast yet</source> <translation>, još nije bio uspješno emitiran</translation> </message> <message> <location line="+35"/> <source>unknown</source> <translation>nepoznato</translation> </message> </context> <context> <name>TransactionDescDialog</name> <message> <location filename="../forms/transactiondescdialog.ui" line="+14"/> <source>Transaction details</source> <translation>Detalji transakcije</translation> </message> <message> <location line="+6"/> <source>This pane shows a detailed description of the transaction</source> <translation>Ova panela prikazuje detaljni opis transakcije</translation> </message> </context> <context> <name>TransactionTableModel</name> <message> <location filename="../transactiontablemodel.cpp" line="+226"/> <source>Date</source> <translation>Datum</translation> </message> <message> <location line="+0"/> <source>Type</source> <translation>Tip</translation> </message> <message> <location line="+0"/> <source>Address</source> <translation>Adresa</translation> </message> <message> <location line="+0"/> <source>Amount</source> <translation>Iznos</translation> </message> <message> <location line="+60"/> <source>Open until %1</source> <translation>Otvoren do %1</translation> </message> <message> <location line="+12"/> <source>Confirmed (%1 confirmations)</source> <translation>Potvrđen (%1 potvrda)</translation> </message> <message numerus="yes"> <location line="-15"/> <source>Open for %n more block(s)</source> <translation type="unfinished"><numerusform></numerusform><numerusform></numerusform><numerusform></numerusform></translation> </message> <message> <location line="+6"/> <source>Offline</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Unconfirmed</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Confirming (%1 of %2 recommended confirmations)</source> <translation type="unfinished"/> </message> <message> <location line="+6"/> <source>Conflicted</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Immature (%1 confirmations, will be available after %2)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>This block was not received by any other nodes and will probably not be accepted!</source> <translation>Generirano - Upozorenje: ovaj blok nije bio primljen od strane bilo kojeg drugog noda i vjerojatno neće biti prihvaćen!</translation> </message> <message> <location line="+3"/> <source>Generated but not accepted</source> <translation>Generirano, ali nije prihvaćeno</translation> </message> <message> <location line="+42"/> <source>Received with</source> <translation>Primljeno s</translation> </message> <message> <location line="+2"/> <source>Received from</source> <translation>Primljeno od</translation> </message> <message> <location line="+3"/> <source>Sent to</source> <translation>Poslano za</translation> </message> <message> <location line="+2"/> <source>Payment to yourself</source> <translation>Plaćanje samom sebi</translation> </message> <message> <location line="+2"/> <source>Mined</source> <translation>Rudareno</translation> </message> <message> <location line="+38"/> <source>(n/a)</source> <translation>(n/d)</translation> </message> <message> <location line="+190"/> <source>Transaction status. Hover over this field to show number of confirmations.</source> <translation>Status transakcije</translation> </message> <message> <location line="+2"/> <source>Date and time that the transaction was received.</source> <translation>Datum i vrijeme kad je transakcija primljena</translation> </message> <message> <location line="+2"/> <source>Type of transaction.</source> <translation>Vrsta transakcije.</translation> </message> <message> <location line="+2"/> <source>Destination address of transaction.</source> <translation>Odredište transakcije</translation> </message> <message> <location line="+2"/> <source>Amount removed from or added to balance.</source> <translation>Iznos odbijen od ili dodan k saldu.</translation> </message> </context> <context> <name>TransactionView</name> <message> <location filename="../transactionview.cpp" line="+55"/> <location line="+16"/> <source>All</source> <translation>Sve</translation> </message> <message> <location line="-15"/> <source>Today</source> <translation>Danas</translation> </message> <message> <location line="+1"/> <source>This week</source> <translation>Ovaj tjedan</translation> </message> <message> <location line="+1"/> <source>This month</source> <translation>Ovaj mjesec</translation> </message> <message> <location line="+1"/> <source>Last month</source> <translation>Prošli mjesec</translation> </message> <message> <location line="+1"/> <source>This year</source> <translation>Ove godine</translation> </message> <message> <location line="+1"/> <source>Range...</source> <translation>Raspon...</translation> </message> <message> <location line="+11"/> <source>Received with</source> <translation>Primljeno s</translation> </message> <message> <location line="+2"/> <source>Sent to</source> <translation>Poslano za</translation> </message> <message> <location line="+2"/> <source>To yourself</source> <translation>Tebi</translation> </message> <message> <location line="+1"/> <source>Mined</source> <translation>Rudareno</translation> </message> <message> <location line="+1"/> <source>Other</source> <translation>Ostalo</translation> </message> <message> <location line="+7"/> <source>Enter address or label to search</source> <translation>Unesite adresu ili oznaku za pretraživanje</translation> </message> <message> <location line="+7"/> <source>Min amount</source> <translation>Min iznos</translation> </message> <message> <location line="+34"/> <source>Copy address</source> <translation>Kopirati adresu</translation> </message> <message> <location line="+1"/> <source>Copy label</source> <translation>Kopirati oznaku</translation> </message> <message> <location line="+1"/> <source>Copy amount</source> <translation>Kopiraj iznos</translation> </message> <message> <location line="+1"/> <source>Copy transaction ID</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Edit label</source> <translation>Izmjeniti oznaku</translation> </message> <message> <location line="+1"/> <source>Show transaction details</source> <translation type="unfinished"/> </message> <message> <location line="+144"/> <source>Export Transaction Data</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Comma separated file (*.csv)</source> <translation>Datoteka podataka odvojenih zarezima (*.csv)</translation> </message> <message> <location line="+8"/> <source>Confirmed</source> <translation>Potvrđeno</translation> </message> <message> <location line="+1"/> <source>Date</source> <translation>Datum</translation> </message> <message> <location line="+1"/> <source>Type</source> <translation>Tip</translation> </message> <message> <location line="+1"/> <source>Label</source> <translation>Oznaka</translation> </message> <message> <location line="+1"/> <source>Address</source> <translation>Adresa</translation> </message> <message> <location line="+1"/> <source>Amount</source> <translation>Iznos</translation> </message> <message> <location line="+1"/> <source>ID</source> <translation>ID</translation> </message> <message> <location line="+4"/> <source>Error exporting</source> <translation type="unfinished"/> </message> <message> <location line="+0"/> <source>Could not write to file %1.</source> <translation type="unfinished"/> </message> <message> <location line="+100"/> <source>Range:</source> <translation>Raspon:</translation> </message> <message> <location line="+8"/> <source>to</source> <translation>za</translation> </message> </context> <context> <name>WalletModel</name> <message> <location filename="../walletmodel.cpp" line="+206"/> <source>Sending...</source> <translation type="unfinished"/> </message> </context> <context> <name>bitcoin-core</name> <message> <location filename="../bitcoinstrings.cpp" line="+33"/> <source>EvilCoin version</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Usage:</source> <translation>Upotreba:</translation> </message> <message> <location line="+1"/> <source>Send command to -server or EvilCoind</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>List commands</source> <translation>Prikaži komande</translation> </message> <message> <location line="+1"/> <source>Get help for a command</source> <translation>Potraži pomoć za komandu</translation> </message> <message> <location line="+2"/> <source>Options:</source> <translation>Postavke:</translation> </message> <message> <location line="+2"/> <source>Specify configuration file (default: EvilCoin.conf)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Specify pid file (default: EvilCoind.pid)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Specify wallet file (within data directory)</source> <translation type="unfinished"/> </message> <message> <location line="-1"/> <source>Specify data directory</source> <translation>Odredi direktorij za datoteke</translation> </message> <message> <location line="+2"/> <source>Set database cache size in megabytes (default: 25)</source> <translation>Postavi cache za bazu podataka u MB (zadano:25)</translation> </message> <message> <location line="+1"/> <source>Set database disk log size in megabytes (default: 100)</source> <translation type="unfinished"/> </message> <message> <location line="+6"/> <source>Listen for connections on &lt;port&gt; (default: 15714 or testnet: 25714)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Maintain at most &lt;n&gt; connections to peers (default: 125)</source> <translation>Održavaj najviše &lt;n&gt; veza sa članovima (default: 125)</translation> </message> <message> <location line="+3"/> <source>Connect to a node to retrieve peer addresses, and disconnect</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Specify your own public address</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Bind to given address. Use [host]:port notation for IPv6</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Stake your coins to support network and gain reward (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Threshold for disconnecting misbehaving peers (default: 100)</source> <translation>Prag za odspajanje članova koji se čudno ponašaju (default: 100)</translation> </message> <message> <location line="+1"/> <source>Number of seconds to keep misbehaving peers from reconnecting (default: 86400)</source> <translation>Broj sekundi koliko se članovima koji se čudno ponašaju neće dopustiti da se opet spoje (default: 86400)</translation> </message> <message> <location line="-44"/> <source>An error occurred while setting up the RPC port %u for listening on IPv4: %s</source> <translation type="unfinished"/> </message> <message> <location line="+51"/> <source>Detach block and address databases. Increases shutdown time (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+109"/> <source>Error: The transaction was rejected. This might happen if some of the coins in your wallet were already spent, such as if you used a copy of wallet.dat and coins were spent in the copy but not marked as spent here.</source> <translation type="unfinished"/> </message> <message> <location line="-5"/> <source>Error: This transaction requires a transaction fee of at least %s because of its amount, complexity, or use of recently received funds </source> <translation type="unfinished"/> </message> <message> <location line="-87"/> <source>Listen for JSON-RPC connections on &lt;port&gt; (default: 15715 or testnet: 25715)</source> <translation type="unfinished"/> </message> <message> <location line="-11"/> <source>Accept command line and JSON-RPC commands</source> <translation>Prihvati komande iz tekst moda i JSON-RPC</translation> </message> <message> <location line="+101"/> <source>Error: Transaction creation failed </source> <translation type="unfinished"/> </message> <message> <location line="-5"/> <source>Error: Wallet locked, unable to create transaction </source> <translation type="unfinished"/> </message> <message> <location line="-8"/> <source>Importing blockchain data file.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Importing bootstrap blockchain data file.</source> <translation type="unfinished"/> </message> <message> <location line="-88"/> <source>Run in the background as a daemon and accept commands</source> <translation>Izvršavaj u pozadini kao uslužnik i prihvaćaj komande</translation> </message> <message> <location line="+1"/> <source>Use the test network</source> <translation>Koristi test mrežu</translation> </message> <message> <location line="-24"/> <source>Accept connections from outside (default: 1 if no -proxy or -connect)</source> <translation type="unfinished"/> </message> <message> <location line="-38"/> <source>An error occurred while setting up the RPC port %u for listening on IPv6, falling back to IPv4: %s</source> <translation type="unfinished"/> </message> <message> <location line="+117"/> <source>Error initializing database environment %s! To recover, BACKUP THAT DIRECTORY, then remove everything from it except for wallet.dat.</source> <translation type="unfinished"/> </message> <message> <location line="-20"/> <source>Set maximum size of high-priority/low-fee transactions in bytes (default: 27000)</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Warning: -paytxfee is set very high! This is the transaction fee you will pay if you send a transaction.</source> <translation>Upozorenje: -paytxfee je podešen na preveliki iznos. To je iznos koji ćete platiti za obradu transakcije.</translation> </message> <message> <location line="+61"/> <source>Warning: Please check that your computer&apos;s date and time are correct! If your clock is wrong EvilCoin will not work properly.</source> <translation type="unfinished"/> </message> <message> <location line="-31"/> <source>Warning: error reading wallet.dat! All keys read correctly, but transaction data or address book entries might be missing or incorrect.</source> <translation type="unfinished"/> </message> <message> <location line="-18"/> <source>Warning: wallet.dat corrupt, data salvaged! Original wallet.dat saved as wallet.{timestamp}.bak in %s; if your balance or transactions are incorrect you should restore from a backup.</source> <translation type="unfinished"/> </message> <message> <location line="-30"/> <source>Attempt to recover private keys from a corrupt wallet.dat</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Block creation options:</source> <translation>Opcije za kreiranje bloka:</translation> </message> <message> <location line="-62"/> <source>Connect only to the specified node(s)</source> <translation>Poveži se samo sa određenim nodom</translation> </message> <message> <location line="+4"/> <source>Discover own IP address (default: 1 when listening and no -externalip)</source> <translation type="unfinished"/> </message> <message> <location line="+94"/> <source>Failed to listen on any port. Use -listen=0 if you want this.</source> <translation type="unfinished"/> </message> <message> <location line="-90"/> <source>Find peers using DNS lookup (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Sync checkpoints policy (default: strict)</source> <translation type="unfinished"/> </message> <message> <location line="+83"/><|fim▁hole|> </message> <message> <location line="+4"/> <source>Invalid amount for -reservebalance=&lt;amount&gt;</source> <translation type="unfinished"/> </message> <message> <location line="-82"/> <source>Maximum per-connection receive buffer, &lt;n&gt;*1000 bytes (default: 5000)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Maximum per-connection send buffer, &lt;n&gt;*1000 bytes (default: 1000)</source> <translation type="unfinished"/> </message> <message> <location line="-16"/> <source>Only connect to nodes in network &lt;net&gt; (IPv4, IPv6 or Tor)</source> <translation type="unfinished"/> </message> <message> <location line="+28"/> <source>Output extra debugging information. Implies all other -debug* options</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Output extra network debugging information</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Prepend debug output with timestamp</source> <translation type="unfinished"/> </message> <message> <location line="+35"/> <source>SSL options: (see the Bitcoin Wiki for SSL setup instructions)</source> <translation>SSL postavke: (za detalje o podešavanju SSL opcija vidi Bitcoin Wiki)</translation> </message> <message> <location line="-74"/> <source>Select the version of socks proxy to use (4-5, default: 5)</source> <translation type="unfinished"/> </message> <message> <location line="+41"/> <source>Send trace/debug info to console instead of debug.log file</source> <translation>Šalji trace/debug informacije na konzolu umjesto u debug.log datoteku</translation> </message> <message> <location line="+1"/> <source>Send trace/debug info to debugger</source> <translation type="unfinished"/> </message> <message> <location line="+28"/> <source>Set maximum block size in bytes (default: 250000)</source> <translation type="unfinished"/> </message> <message> <location line="-1"/> <source>Set minimum block size in bytes (default: 0)</source> <translation>Podesite minimalnu veličinu bloka u bajtovima (default: 0)</translation> </message> <message> <location line="-29"/> <source>Shrink debug.log file on client startup (default: 1 when no -debug)</source> <translation type="unfinished"/> </message> <message> <location line="-42"/> <source>Specify connection timeout in milliseconds (default: 5000)</source> <translation>Odredi vremenski prozor za spajanje na mrežu u milisekundama (ugrađeni izbor: 5000)</translation> </message> <message> <location line="+109"/> <source>Unable to sign checkpoint, wrong checkpointkey? </source> <translation type="unfinished"/> </message> <message> <location line="-80"/> <source>Use UPnP to map the listening port (default: 0)</source> <translation>Pokušaj koristiti UPnP da otvoriš port za uslugu (default: 0)</translation> </message> <message> <location line="-1"/> <source>Use UPnP to map the listening port (default: 1 when listening)</source> <translation>Pokušaj koristiti UPnP da otvoriš port za uslugu (default: 1 when listening)</translation> </message> <message> <location line="-25"/> <source>Use proxy to reach tor hidden services (default: same as -proxy)</source> <translation type="unfinished"/> </message> <message> <location line="+42"/> <source>Username for JSON-RPC connections</source> <translation>Korisničko ime za JSON-RPC veze</translation> </message> <message> <location line="+47"/> <source>Verifying database integrity...</source> <translation type="unfinished"/> </message> <message> <location line="+57"/> <source>WARNING: syncronized checkpoint violation detected, but skipped!</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Warning: Disk space is low!</source> <translation type="unfinished"/> </message> <message> <location line="-2"/> <source>Warning: This version is obsolete, upgrade required!</source> <translation type="unfinished"/> </message> <message> <location line="-48"/> <source>wallet.dat corrupt, salvage failed</source> <translation type="unfinished"/> </message> <message> <location line="-54"/> <source>Password for JSON-RPC connections</source> <translation>Lozinka za JSON-RPC veze</translation> </message> <message> <location line="-84"/> <source>%s, you must set a rpcpassword in the configuration file: %s It is recommended you use the following random password: rpcuser=EvilCoinrpc rpcpassword=%s (you do not need to remember this password) The username and password MUST NOT be the same. If the file does not exist, create it with owner-readable-only file permissions. It is also recommended to set alertnotify so you are notified of problems; for example: alertnotify=echo %%s | mail -s &quot;EvilCoin Alert&quot; [email protected] </source> <translation type="unfinished"/> </message> <message> <location line="+51"/> <source>Find peers using internet relay chat (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Sync time with other nodes. Disable if time on your system is precise e.g. syncing with NTP (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+15"/> <source>When creating transactions, ignore inputs with value less than this (default: 0.01)</source> <translation type="unfinished"/> </message> <message> <location line="+16"/> <source>Allow JSON-RPC connections from specified IP address</source> <translation>Dozvoli JSON-RPC povezivanje s određene IP adrese</translation> </message> <message> <location line="+1"/> <source>Send commands to node running on &lt;ip&gt; (default: 127.0.0.1)</source> <translation>Pošalji komande nodu na adresi &lt;ip&gt; (ugrađeni izbor: 127.0.0.1)</translation> </message> <message> <location line="+1"/> <source>Execute command when the best block changes (%s in cmd is replaced by block hash)</source> <translation>Izvršite naredbu kada se najbolji blok promjeni (%s u cmd je zamjenjen sa block hash)</translation> </message> <message> <location line="+3"/> <source>Execute command when a wallet transaction changes (%s in cmd is replaced by TxID)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Require a confirmations for change (default: 0)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Enforce transaction scripts to use canonical PUSH operators (default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Execute command when a relevant alert is received (%s in cmd is replaced by message)</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Upgrade wallet to latest format</source> <translation>Nadogradite novčanik u posljednji format.</translation> </message> <message> <location line="+1"/> <source>Set key pool size to &lt;n&gt; (default: 100)</source> <translation>Podesi memorijski prostor za ključeve na &lt;n&gt; (ugrađeni izbor: 100)</translation> </message> <message> <location line="+1"/> <source>Rescan the block chain for missing wallet transactions</source> <translation>Ponovno pretraži lanac blokova za transakcije koje nedostaju</translation> </message> <message> <location line="+2"/> <source>How many blocks to check at startup (default: 2500, 0 = all)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>How thorough the block verification is (0-6, default: 1)</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Imports blocks from external blk000?.dat file</source> <translation type="unfinished"/> </message> <message> <location line="+8"/> <source>Use OpenSSL (https) for JSON-RPC connections</source> <translation>Koristi OpenSSL (https) za JSON-RPC povezivanje</translation> </message> <message> <location line="+1"/> <source>Server certificate file (default: server.cert)</source> <translation>Uslužnikov SSL certifikat (ugrađeni izbor: server.cert)</translation> </message> <message> <location line="+1"/> <source>Server private key (default: server.pem)</source> <translation>Uslužnikov privatni ključ (ugrađeni izbor: server.pem)</translation> </message> <message> <location line="+1"/> <source>Acceptable ciphers (default: TLSv1+HIGH:!SSLv2:!aNULL:!eNULL:!AH:!3DES:@STRENGTH)</source> <translation type="unfinished"/> </message> <message> <location line="+53"/> <source>Error: Wallet unlocked for staking only, unable to create transaction.</source> <translation type="unfinished"/> </message> <message> <location line="+18"/> <source>WARNING: Invalid checkpoint found! Displayed transactions may not be correct! You may need to upgrade, or notify developers.</source> <translation type="unfinished"/> </message> <message> <location line="-158"/> <source>This help message</source> <translation>Ova poruka za pomoć</translation> </message> <message> <location line="+95"/> <source>Wallet %s resides outside data directory %s.</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Cannot obtain a lock on data directory %s. EvilCoin is probably already running.</source> <translation type="unfinished"/> </message> <message> <location line="-98"/> <source>EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+140"/> <source>Unable to bind to %s on this computer (bind returned error %d, %s)</source> <translation>Program ne može koristiti %s na ovom računalu (bind returned error %d, %s)</translation> </message> <message> <location line="-130"/> <source>Connect through socks proxy</source> <translation type="unfinished"/> </message> <message> <location line="+3"/> <source>Allow DNS lookups for -addnode, -seednode and -connect</source> <translation>Dozvoli DNS upite za dodavanje nodova i povezivanje</translation> </message> <message> <location line="+122"/> <source>Loading addresses...</source> <translation>Učitavanje adresa...</translation> </message> <message> <location line="-15"/> <source>Error loading blkindex.dat</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Error loading wallet.dat: Wallet corrupted</source> <translation>Greška kod učitavanja wallet.dat: Novčanik pokvaren</translation> </message> <message> <location line="+4"/> <source>Error loading wallet.dat: Wallet requires newer version of EvilCoin</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Wallet needed to be rewritten: restart EvilCoin to complete</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Error loading wallet.dat</source> <translation>Greška kod učitavanja wallet.dat</translation> </message> <message> <location line="-16"/> <source>Invalid -proxy address: &apos;%s&apos;</source> <translation>Nevaljala -proxy adresa: &apos;%s&apos;</translation> </message> <message> <location line="-1"/> <source>Unknown network specified in -onlynet: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="-1"/> <source>Unknown -socks proxy version requested: %i</source> <translation type="unfinished"/> </message> <message> <location line="+4"/> <source>Cannot resolve -bind address: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+2"/> <source>Cannot resolve -externalip address: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="-24"/> <source>Invalid amount for -paytxfee=&lt;amount&gt;: &apos;%s&apos;</source> <translation>Nevaljali iznos za opciju -paytxfee=&lt;amount&gt;: &apos;%s&apos;</translation> </message> <message> <location line="+44"/> <source>Error: could not start node</source> <translation type="unfinished"/> </message> <message> <location line="+11"/> <source>Sending...</source> <translation type="unfinished"/> </message> <message> <location line="+5"/> <source>Invalid amount</source> <translation>Nevaljali iznos za opciju</translation> </message> <message> <location line="+1"/> <source>Insufficient funds</source> <translation>Nedovoljna sredstva</translation> </message> <message> <location line="-34"/> <source>Loading block index...</source> <translation>Učitavanje indeksa blokova...</translation> </message> <message> <location line="-103"/> <source>Add a node to connect to and attempt to keep the connection open</source> <translation>Unesite nod s kojim se želite spojiti and attempt to keep the connection open</translation> </message> <message> <location line="+122"/> <source>Unable to bind to %s on this computer. EvilCoin is probably already running.</source> <translation type="unfinished"/> </message> <message> <location line="-97"/> <source>Fee per KB to add to transactions you send</source> <translation type="unfinished"/> </message> <message> <location line="+55"/> <source>Invalid amount for -mininput=&lt;amount&gt;: &apos;%s&apos;</source> <translation type="unfinished"/> </message> <message> <location line="+25"/> <source>Loading wallet...</source> <translation>Učitavanje novčanika...</translation> </message> <message> <location line="+8"/> <source>Cannot downgrade wallet</source> <translation>Nije moguće novčanik vratiti na prijašnju verziju.</translation> </message> <message> <location line="+1"/> <source>Cannot initialize keypool</source> <translation type="unfinished"/> </message> <message> <location line="+1"/> <source>Cannot write default address</source> <translation>Nije moguće upisati zadanu adresu.</translation> </message> <message> <location line="+1"/> <source>Rescanning...</source> <translation>Rescaniranje</translation> </message> <message> <location line="+5"/> <source>Done loading</source> <translation>Učitavanje gotovo</translation> </message> <message> <location line="-167"/> <source>To use the %s option</source> <translation type="unfinished"/> </message> <message> <location line="+14"/> <source>Error</source> <translation>Greška</translation> </message> <message> <location line="+6"/> <source>You must set rpcpassword=&lt;password&gt; in the configuration file: %s If the file does not exist, create it with owner-readable-only file permissions.</source> <translation type="unfinished"/> </message> </context> </TS><|fim▁end|>
<source>Invalid -tor address: &apos;%s&apos;</source> <translation type="unfinished"/>
<|file_name|>EditorWindow.py<|end_file_name|><|fim▁begin|>import sys import os import platform import re import imp from Tkinter import * import tkSimpleDialog import tkMessageBox import webbrowser from idlelib.MultiCall import MultiCallCreator from idlelib import idlever from idlelib import WindowList from idlelib import SearchDialog from idlelib import GrepDialog from idlelib import ReplaceDialog from idlelib import PyParse from idlelib.configHandler import idleConf from idlelib import aboutDialog, textView, configDialog from idlelib import macosxSupport # The default tab setting for a Text widget, in average-width characters. TK_TABWIDTH_DEFAULT = 8 _py_version = ' (%s)' % platform.python_version() def _sphinx_version(): "Format sys.version_info to produce the Sphinx version string used to install the chm docs" major, minor, micro, level, serial = sys.version_info release = '%s%s' % (major, minor) if micro: release += '%s' % (micro,) if level == 'candidate': release += 'rc%s' % (serial,) elif level != 'final': release += '%s%s' % (level[0], serial) return release def _find_module(fullname, path=None): """Version of imp.find_module() that handles hierarchical module names""" file = None for tgt in fullname.split('.'): if file is not None: file.close() # close intermediate files (file, filename, descr) = imp.find_module(tgt, path) if descr[2] == imp.PY_SOURCE: break # find but not load the source file module = imp.load_module(tgt, file, filename, descr) try: path = module.__path__ except AttributeError: raise ImportError, 'No source for module ' + module.__name__ if descr[2] != imp.PY_SOURCE: # If all of the above fails and didn't raise an exception,fallback # to a straight import which can find __init__.py in a package. m = __import__(fullname) try: filename = m.__file__ except AttributeError: pass else: file = None base, ext = os.path.splitext(filename) if ext == '.pyc': ext = '.py' filename = base + ext descr = filename, None, imp.PY_SOURCE return file, filename, descr class HelpDialog(object): def __init__(self): self.parent = None # parent of help window self.dlg = None # the help window iteself def display(self, parent, near=None): """ Display the help dialog. parent - parent widget for the help window near - a Toplevel widget (e.g. EditorWindow or PyShell) to use as a reference for placing the help window """ if self.dlg is None: self.show_dialog(parent) if near: self.nearwindow(near) def show_dialog(self, parent): self.parent = parent fn=os.path.join(os.path.abspath(os.path.dirname(__file__)),'help.txt') self.dlg = dlg = textView.view_file(parent,'Help',fn, modal=False) dlg.bind('<Destroy>', self.destroy, '+') def nearwindow(self, near): # Place the help dialog near the window specified by parent. # Note - this may not reposition the window in Metacity # if "/apps/metacity/general/disable_workarounds" is enabled dlg = self.dlg geom = (near.winfo_rootx() + 10, near.winfo_rooty() + 10) dlg.withdraw() dlg.geometry("=+%d+%d" % geom) dlg.deiconify() dlg.lift() def destroy(self, ev=None): self.dlg = None self.parent = None helpDialog = HelpDialog() # singleton instance def _help_dialog(parent): # wrapper for htest helpDialog.show_dialog(parent) class EditorWindow(object): from idlelib.Percolator import Percolator from idlelib.ColorDelegator import ColorDelegator from idlelib.UndoDelegator import UndoDelegator from idlelib.IOBinding import IOBinding, filesystemencoding, encoding from idlelib import Bindings from Tkinter import Toplevel from idlelib.MultiStatusBar import MultiStatusBar help_url = None def __init__(self, flist=None, filename=None, key=None, root=None): if EditorWindow.help_url is None: dochome = os.path.join(sys.prefix, 'Doc', 'index.html') if sys.platform.count('linux'): # look for html docs in a couple of standard places pyver = 'python-docs-' + '%s.%s.%s' % sys.version_info[:3] if os.path.isdir('/var/www/html/python/'): # "python2" rpm dochome = '/var/www/html/python/index.html' else: basepath = '/usr/share/doc/' # standard location dochome = os.path.join(basepath, pyver, 'Doc', 'index.html') elif sys.platform[:3] == 'win': chmfile = os.path.join(sys.prefix, 'Doc', 'Python%s.chm' % _sphinx_version()) if os.path.isfile(chmfile): dochome = chmfile elif sys.platform == 'darwin': # documentation may be stored inside a python framework dochome = os.path.join(sys.prefix, 'Resources/English.lproj/Documentation/index.html') dochome = os.path.normpath(dochome) if os.path.isfile(dochome): EditorWindow.help_url = dochome if sys.platform == 'darwin': # Safari requires real file:-URLs EditorWindow.help_url = 'file://' + EditorWindow.help_url else: EditorWindow.help_url = "https://docs.python.org/%d.%d/" % sys.version_info[:2] currentTheme=idleConf.CurrentTheme() self.flist = flist root = root or flist.root self.root = root try: sys.ps1 except AttributeError: sys.ps1 = '>>> ' self.menubar = Menu(root) self.top = top = WindowList.ListedToplevel(root, menu=self.menubar) if flist: self.tkinter_vars = flist.vars #self.top.instance_dict makes flist.inversedict available to #configDialog.py so it can access all EditorWindow instances self.top.instance_dict = flist.inversedict else: self.tkinter_vars = {} # keys: Tkinter event names # values: Tkinter variable instances self.top.instance_dict = {} self.recent_files_path = os.path.join(idleConf.GetUserCfgDir(), 'recent-files.lst') self.text_frame = text_frame = Frame(top) self.vbar = vbar = Scrollbar(text_frame, name='vbar') self.width = idleConf.GetOption('main','EditorWindow','width', type='int') text_options = { 'name': 'text', 'padx': 5, 'wrap': 'none', 'width': self.width, 'height': idleConf.GetOption('main', 'EditorWindow', 'height', type='int')} if TkVersion >= 8.5: # Starting with tk 8.5 we have to set the new tabstyle option # to 'wordprocessor' to achieve the same display of tabs as in # older tk versions. text_options['tabstyle'] = 'wordprocessor' self.text = text = MultiCallCreator(Text)(text_frame, **text_options) self.top.focused_widget = self.text self.createmenubar() self.apply_bindings() self.top.protocol("WM_DELETE_WINDOW", self.close) self.top.bind("<<close-window>>", self.close_event) if macosxSupport.isAquaTk(): # Command-W on editorwindows doesn't work without this. text.bind('<<close-window>>', self.close_event) # Some OS X systems have only one mouse button, # so use control-click for pulldown menus there. # (Note, AquaTk defines <2> as the right button if # present and the Tk Text widget already binds <2>.) text.bind("<Control-Button-1>",self.right_menu_event) else: # Elsewhere, use right-click for pulldown menus. text.bind("<3>",self.right_menu_event) text.bind("<<cut>>", self.cut) text.bind("<<copy>>", self.copy) text.bind("<<paste>>", self.paste) text.bind("<<center-insert>>", self.center_insert_event) text.bind("<<help>>", self.help_dialog) text.bind("<<python-docs>>", self.python_docs) text.bind("<<about-idle>>", self.about_dialog) text.bind("<<open-config-dialog>>", self.config_dialog) text.bind("<<open-config-extensions-dialog>>", self.config_extensions_dialog) text.bind("<<open-module>>", self.open_module) text.bind("<<do-nothing>>", lambda event: "break") text.bind("<<select-all>>", self.select_all) text.bind("<<remove-selection>>", self.remove_selection) text.bind("<<find>>", self.find_event) text.bind("<<find-again>>", self.find_again_event) text.bind("<<find-in-files>>", self.find_in_files_event) text.bind("<<find-selection>>", self.find_selection_event) text.bind("<<replace>>", self.replace_event) text.bind("<<goto-line>>", self.goto_line_event) text.bind("<<smart-backspace>>",self.smart_backspace_event) text.bind("<<newline-and-indent>>",self.newline_and_indent_event) text.bind("<<smart-indent>>",self.smart_indent_event) text.bind("<<indent-region>>",self.indent_region_event) text.bind("<<dedent-region>>",self.dedent_region_event) text.bind("<<comment-region>>",self.comment_region_event) text.bind("<<uncomment-region>>",self.uncomment_region_event) text.bind("<<tabify-region>>",self.tabify_region_event) text.bind("<<untabify-region>>",self.untabify_region_event) text.bind("<<toggle-tabs>>",self.toggle_tabs_event) text.bind("<<change-indentwidth>>",self.change_indentwidth_event) text.bind("<Left>", self.move_at_edge_if_selection(0)) text.bind("<Right>", self.move_at_edge_if_selection(1)) text.bind("<<del-word-left>>", self.del_word_left) text.bind("<<del-word-right>>", self.del_word_right) text.bind("<<beginning-of-line>>", self.home_callback) if flist: flist.inversedict[self] = key if key: flist.dict[key] = self text.bind("<<open-new-window>>", self.new_callback) text.bind("<<close-all-windows>>", self.flist.close_all_callback) text.bind("<<open-class-browser>>", self.open_class_browser) text.bind("<<open-path-browser>>", self.open_path_browser) self.set_status_bar() vbar['command'] = text.yview vbar.pack(side=RIGHT, fill=Y) text['yscrollcommand'] = vbar.set fontWeight = 'normal' if idleConf.GetOption('main', 'EditorWindow', 'font-bold', type='bool'): fontWeight='bold' text.config(font=(idleConf.GetOption('main', 'EditorWindow', 'font'), idleConf.GetOption('main', 'EditorWindow', 'font-size', type='int'), fontWeight)) text_frame.pack(side=LEFT, fill=BOTH, expand=1) text.pack(side=TOP, fill=BOTH, expand=1) text.focus_set() # usetabs true -> literal tab characters are used by indent and # dedent cmds, possibly mixed with spaces if # indentwidth is not a multiple of tabwidth, # which will cause Tabnanny to nag! # false -> tab characters are converted to spaces by indent # and dedent cmds, and ditto TAB keystrokes # Although use-spaces=0 can be configured manually in config-main.def, # configuration of tabs v. spaces is not supported in the configuration # dialog. IDLE promotes the preferred Python indentation: use spaces! usespaces = idleConf.GetOption('main', 'Indent', 'use-spaces', type='bool') self.usetabs = not usespaces # tabwidth is the display width of a literal tab character. # CAUTION: telling Tk to use anything other than its default # tab setting causes it to use an entirely different tabbing algorithm, # treating tab stops as fixed distances from the left margin. # Nobody expects this, so for now tabwidth should never be changed. self.tabwidth = 8 # must remain 8 until Tk is fixed. # indentwidth is the number of screen characters per indent level. # The recommended Python indentation is four spaces. self.indentwidth = self.tabwidth self.set_notabs_indentwidth() # If context_use_ps1 is true, parsing searches back for a ps1 line; # else searches for a popular (if, def, ...) Python stmt. self.context_use_ps1 = False # When searching backwards for a reliable place to begin parsing, # first start num_context_lines[0] lines back, then # num_context_lines[1] lines back if that didn't work, and so on. # The last value should be huge (larger than the # of lines in a # conceivable file). # Making the initial values larger slows things down more often. self.num_context_lines = 50, 500, 5000000 self.per = per = self.Percolator(text) self.undo = undo = self.UndoDelegator() per.insertfilter(undo) text.undo_block_start = undo.undo_block_start text.undo_block_stop = undo.undo_block_stop undo.set_saved_change_hook(self.saved_change_hook) # IOBinding implements file I/O and printing functionality self.io = io = self.IOBinding(self) io.set_filename_change_hook(self.filename_change_hook) # Create the recent files submenu self.recent_files_menu = Menu(self.menubar) self.menudict['file'].insert_cascade(3, label='Recent Files', underline=0, menu=self.recent_files_menu) self.update_recent_files_list() self.color = None # initialized below in self.ResetColorizer if filename: if os.path.exists(filename) and not os.path.isdir(filename): io.loadfile(filename) else: io.set_filename(filename) self.ResetColorizer() self.saved_change_hook() self.set_indentation_params(self.ispythonsource(filename)) self.load_extensions() menu = self.menudict.get('windows') if menu: end = menu.index("end") if end is None: end = -1 if end >= 0: menu.add_separator() end = end + 1 self.wmenu_end = end WindowList.register_callback(self.postwindowsmenu) # Some abstractions so IDLE extensions are cross-IDE self.askyesno = tkMessageBox.askyesno self.askinteger = tkSimpleDialog.askinteger self.showerror = tkMessageBox.showerror<|fim▁hole|> self._highlight_workaround() # Fix selection tags on Windows def _highlight_workaround(self): # On Windows, Tk removes painting of the selection # tags which is different behavior than on Linux and Mac. # See issue14146 for more information. if not sys.platform.startswith('win'): return text = self.text text.event_add("<<Highlight-FocusOut>>", "<FocusOut>") text.event_add("<<Highlight-FocusIn>>", "<FocusIn>") def highlight_fix(focus): sel_range = text.tag_ranges("sel") if sel_range: if focus == 'out': HILITE_CONFIG = idleConf.GetHighlight( idleConf.CurrentTheme(), 'hilite') text.tag_config("sel_fix", HILITE_CONFIG) text.tag_raise("sel_fix") text.tag_add("sel_fix", *sel_range) elif focus == 'in': text.tag_remove("sel_fix", "1.0", "end") text.bind("<<Highlight-FocusOut>>", lambda ev: highlight_fix("out")) text.bind("<<Highlight-FocusIn>>", lambda ev: highlight_fix("in")) def _filename_to_unicode(self, filename): """convert filename to unicode in order to display it in Tk""" if isinstance(filename, unicode) or not filename: return filename else: try: return filename.decode(self.filesystemencoding) except UnicodeDecodeError: # XXX try: return filename.decode(self.encoding) except UnicodeDecodeError: # byte-to-byte conversion return filename.decode('iso8859-1') def new_callback(self, event): dirname, basename = self.io.defaultfilename() self.flist.new(dirname) return "break" def home_callback(self, event): if (event.state & 4) != 0 and event.keysym == "Home": # state&4==Control. If <Control-Home>, use the Tk binding. return if self.text.index("iomark") and \ self.text.compare("iomark", "<=", "insert lineend") and \ self.text.compare("insert linestart", "<=", "iomark"): # In Shell on input line, go to just after prompt insertpt = int(self.text.index("iomark").split(".")[1]) else: line = self.text.get("insert linestart", "insert lineend") for insertpt in xrange(len(line)): if line[insertpt] not in (' ','\t'): break else: insertpt=len(line) lineat = int(self.text.index("insert").split('.')[1]) if insertpt == lineat: insertpt = 0 dest = "insert linestart+"+str(insertpt)+"c" if (event.state&1) == 0: # shift was not pressed self.text.tag_remove("sel", "1.0", "end") else: if not self.text.index("sel.first"): self.text.mark_set("my_anchor", "insert") # there was no previous selection else: if self.text.compare(self.text.index("sel.first"), "<", self.text.index("insert")): self.text.mark_set("my_anchor", "sel.first") # extend back else: self.text.mark_set("my_anchor", "sel.last") # extend forward first = self.text.index(dest) last = self.text.index("my_anchor") if self.text.compare(first,">",last): first,last = last,first self.text.tag_remove("sel", "1.0", "end") self.text.tag_add("sel", first, last) self.text.mark_set("insert", dest) self.text.see("insert") return "break" def set_status_bar(self): self.status_bar = self.MultiStatusBar(self.top) if sys.platform == "darwin": # Insert some padding to avoid obscuring some of the statusbar # by the resize widget. self.status_bar.set_label('_padding1', ' ', side=RIGHT) self.status_bar.set_label('column', 'Col: ?', side=RIGHT) self.status_bar.set_label('line', 'Ln: ?', side=RIGHT) self.status_bar.pack(side=BOTTOM, fill=X) self.text.bind("<<set-line-and-column>>", self.set_line_and_column) self.text.event_add("<<set-line-and-column>>", "<KeyRelease>", "<ButtonRelease>") self.text.after_idle(self.set_line_and_column) def set_line_and_column(self, event=None): line, column = self.text.index(INSERT).split('.') self.status_bar.set_label('column', 'Col: %s' % column) self.status_bar.set_label('line', 'Ln: %s' % line) menu_specs = [ ("file", "_File"), ("edit", "_Edit"), ("format", "F_ormat"), ("run", "_Run"), ("options", "_Options"), ("windows", "_Windows"), ("help", "_Help"), ] if sys.platform == "darwin": menu_specs[-2] = ("windows", "_Window") def createmenubar(self): mbar = self.menubar self.menudict = menudict = {} for name, label in self.menu_specs: underline, label = prepstr(label) menudict[name] = menu = Menu(mbar, name=name) mbar.add_cascade(label=label, menu=menu, underline=underline) if macosxSupport.isCarbonTk(): # Insert the application menu menudict['application'] = menu = Menu(mbar, name='apple') mbar.add_cascade(label='IDLE', menu=menu) self.fill_menus() self.base_helpmenu_length = self.menudict['help'].index(END) self.reset_help_menu_entries() def postwindowsmenu(self): # Only called when Windows menu exists menu = self.menudict['windows'] end = menu.index("end") if end is None: end = -1 if end > self.wmenu_end: menu.delete(self.wmenu_end+1, end) WindowList.add_windows_to_menu(menu) rmenu = None def right_menu_event(self, event): self.text.mark_set("insert", "@%d,%d" % (event.x, event.y)) if not self.rmenu: self.make_rmenu() rmenu = self.rmenu self.event = event iswin = sys.platform[:3] == 'win' if iswin: self.text.config(cursor="arrow") for item in self.rmenu_specs: try: label, eventname, verify_state = item except ValueError: # see issue1207589 continue if verify_state is None: continue state = getattr(self, verify_state)() rmenu.entryconfigure(label, state=state) rmenu.tk_popup(event.x_root, event.y_root) if iswin: self.text.config(cursor="ibeam") rmenu_specs = [ # ("Label", "<<virtual-event>>", "statefuncname"), ... ("Close", "<<close-window>>", None), # Example ] def make_rmenu(self): rmenu = Menu(self.text, tearoff=0) for item in self.rmenu_specs: label, eventname = item[0], item[1] if label is not None: def command(text=self.text, eventname=eventname): text.event_generate(eventname) rmenu.add_command(label=label, command=command) else: rmenu.add_separator() self.rmenu = rmenu def rmenu_check_cut(self): return self.rmenu_check_copy() def rmenu_check_copy(self): try: indx = self.text.index('sel.first') except TclError: return 'disabled' else: return 'normal' if indx else 'disabled' def rmenu_check_paste(self): try: self.text.tk.call('tk::GetSelection', self.text, 'CLIPBOARD') except TclError: return 'disabled' else: return 'normal' def about_dialog(self, event=None): aboutDialog.AboutDialog(self.top,'About IDLE') def config_dialog(self, event=None): configDialog.ConfigDialog(self.top,'Settings') def config_extensions_dialog(self, event=None): configDialog.ConfigExtensionsDialog(self.top) def help_dialog(self, event=None): if self.root: parent = self.root else: parent = self.top helpDialog.display(parent, near=self.top) def python_docs(self, event=None): if sys.platform[:3] == 'win': try: os.startfile(self.help_url) except WindowsError as why: tkMessageBox.showerror(title='Document Start Failure', message=str(why), parent=self.text) else: webbrowser.open(self.help_url) return "break" def cut(self,event): self.text.event_generate("<<Cut>>") return "break" def copy(self,event): if not self.text.tag_ranges("sel"): # There is no selection, so do nothing and maybe interrupt. return self.text.event_generate("<<Copy>>") return "break" def paste(self,event): self.text.event_generate("<<Paste>>") self.text.see("insert") return "break" def select_all(self, event=None): self.text.tag_add("sel", "1.0", "end-1c") self.text.mark_set("insert", "1.0") self.text.see("insert") return "break" def remove_selection(self, event=None): self.text.tag_remove("sel", "1.0", "end") self.text.see("insert") def move_at_edge_if_selection(self, edge_index): """Cursor move begins at start or end of selection When a left/right cursor key is pressed create and return to Tkinter a function which causes a cursor move from the associated edge of the selection. """ self_text_index = self.text.index self_text_mark_set = self.text.mark_set edges_table = ("sel.first+1c", "sel.last-1c") def move_at_edge(event): if (event.state & 5) == 0: # no shift(==1) or control(==4) pressed try: self_text_index("sel.first") self_text_mark_set("insert", edges_table[edge_index]) except TclError: pass return move_at_edge def del_word_left(self, event): self.text.event_generate('<Meta-Delete>') return "break" def del_word_right(self, event): self.text.event_generate('<Meta-d>') return "break" def find_event(self, event): SearchDialog.find(self.text) return "break" def find_again_event(self, event): SearchDialog.find_again(self.text) return "break" def find_selection_event(self, event): SearchDialog.find_selection(self.text) return "break" def find_in_files_event(self, event): GrepDialog.grep(self.text, self.io, self.flist) return "break" def replace_event(self, event): ReplaceDialog.replace(self.text) return "break" def goto_line_event(self, event): text = self.text lineno = tkSimpleDialog.askinteger("Goto", "Go to line number:",parent=text) if lineno is None: return "break" if lineno <= 0: text.bell() return "break" text.mark_set("insert", "%d.0" % lineno) text.see("insert") def open_module(self, event=None): # XXX Shouldn't this be in IOBinding or in FileList? try: name = self.text.get("sel.first", "sel.last") except TclError: name = "" else: name = name.strip() name = tkSimpleDialog.askstring("Module", "Enter the name of a Python module\n" "to search on sys.path and open:", parent=self.text, initialvalue=name) if name: name = name.strip() if not name: return # XXX Ought to insert current file's directory in front of path try: (f, file_path, (suffix, mode, mtype)) = _find_module(name) except (NameError, ImportError) as msg: tkMessageBox.showerror("Import error", str(msg), parent=self.text) return if mtype != imp.PY_SOURCE: tkMessageBox.showerror("Unsupported type", "%s is not a source module" % name, parent=self.text) return if f: f.close() if self.flist: self.flist.open(file_path) else: self.io.loadfile(file_path) return file_path def open_class_browser(self, event=None): filename = self.io.filename if not (self.__class__.__name__ == 'PyShellEditorWindow' and filename): filename = self.open_module() if filename is None: return head, tail = os.path.split(filename) base, ext = os.path.splitext(tail) from idlelib import ClassBrowser ClassBrowser.ClassBrowser(self.flist, base, [head]) def open_path_browser(self, event=None): from idlelib import PathBrowser PathBrowser.PathBrowser(self.flist) def gotoline(self, lineno): if lineno is not None and lineno > 0: self.text.mark_set("insert", "%d.0" % lineno) self.text.tag_remove("sel", "1.0", "end") self.text.tag_add("sel", "insert", "insert +1l") self.center() def ispythonsource(self, filename): if not filename or os.path.isdir(filename): return True base, ext = os.path.splitext(os.path.basename(filename)) if os.path.normcase(ext) in (".py", ".pyw"): return True try: f = open(filename) line = f.readline() f.close() except IOError: return False return line.startswith('#!') and line.find('python') >= 0 def close_hook(self): if self.flist: self.flist.unregister_maybe_terminate(self) self.flist = None def set_close_hook(self, close_hook): self.close_hook = close_hook def filename_change_hook(self): if self.flist: self.flist.filename_changed_edit(self) self.saved_change_hook() self.top.update_windowlist_registry(self) self.ResetColorizer() def _addcolorizer(self): if self.color: return if self.ispythonsource(self.io.filename): self.color = self.ColorDelegator() # can add more colorizers here... if self.color: self.per.removefilter(self.undo) self.per.insertfilter(self.color) self.per.insertfilter(self.undo) def _rmcolorizer(self): if not self.color: return self.color.removecolors() self.per.removefilter(self.color) self.color = None def ResetColorizer(self): "Update the color theme" # Called from self.filename_change_hook and from configDialog.py self._rmcolorizer() self._addcolorizer() theme = idleConf.GetOption('main','Theme','name') normal_colors = idleConf.GetHighlight(theme, 'normal') cursor_color = idleConf.GetHighlight(theme, 'cursor', fgBg='fg') select_colors = idleConf.GetHighlight(theme, 'hilite') self.text.config( foreground=normal_colors['foreground'], background=normal_colors['background'], insertbackground=cursor_color, selectforeground=select_colors['foreground'], selectbackground=select_colors['background'], ) def ResetFont(self): "Update the text widgets' font if it is changed" # Called from configDialog.py fontWeight='normal' if idleConf.GetOption('main','EditorWindow','font-bold',type='bool'): fontWeight='bold' self.text.config(font=(idleConf.GetOption('main','EditorWindow','font'), idleConf.GetOption('main','EditorWindow','font-size', type='int'), fontWeight)) def RemoveKeybindings(self): "Remove the keybindings before they are changed." # Called from configDialog.py self.Bindings.default_keydefs = keydefs = idleConf.GetCurrentKeySet() for event, keylist in keydefs.items(): self.text.event_delete(event, *keylist) for extensionName in self.get_standard_extension_names(): xkeydefs = idleConf.GetExtensionBindings(extensionName) if xkeydefs: for event, keylist in xkeydefs.items(): self.text.event_delete(event, *keylist) def ApplyKeybindings(self): "Update the keybindings after they are changed" # Called from configDialog.py self.Bindings.default_keydefs = keydefs = idleConf.GetCurrentKeySet() self.apply_bindings() for extensionName in self.get_standard_extension_names(): xkeydefs = idleConf.GetExtensionBindings(extensionName) if xkeydefs: self.apply_bindings(xkeydefs) #update menu accelerators menuEventDict = {} for menu in self.Bindings.menudefs: menuEventDict[menu[0]] = {} for item in menu[1]: if item: menuEventDict[menu[0]][prepstr(item[0])[1]] = item[1] for menubarItem in self.menudict.keys(): menu = self.menudict[menubarItem] end = menu.index(END) if end is None: # Skip empty menus continue end += 1 for index in range(0, end): if menu.type(index) == 'command': accel = menu.entrycget(index, 'accelerator') if accel: itemName = menu.entrycget(index, 'label') event = '' if menubarItem in menuEventDict: if itemName in menuEventDict[menubarItem]: event = menuEventDict[menubarItem][itemName] if event: accel = get_accelerator(keydefs, event) menu.entryconfig(index, accelerator=accel) def set_notabs_indentwidth(self): "Update the indentwidth if changed and not using tabs in this window" # Called from configDialog.py if not self.usetabs: self.indentwidth = idleConf.GetOption('main', 'Indent','num-spaces', type='int') def reset_help_menu_entries(self): "Update the additional help entries on the Help menu" help_list = idleConf.GetAllExtraHelpSourcesList() helpmenu = self.menudict['help'] # first delete the extra help entries, if any helpmenu_length = helpmenu.index(END) if helpmenu_length > self.base_helpmenu_length: helpmenu.delete((self.base_helpmenu_length + 1), helpmenu_length) # then rebuild them if help_list: helpmenu.add_separator() for entry in help_list: cmd = self.__extra_help_callback(entry[1]) helpmenu.add_command(label=entry[0], command=cmd) # and update the menu dictionary self.menudict['help'] = helpmenu def __extra_help_callback(self, helpfile): "Create a callback with the helpfile value frozen at definition time" def display_extra_help(helpfile=helpfile): if not helpfile.startswith(('www', 'http')): helpfile = os.path.normpath(helpfile) if sys.platform[:3] == 'win': try: os.startfile(helpfile) except WindowsError as why: tkMessageBox.showerror(title='Document Start Failure', message=str(why), parent=self.text) else: webbrowser.open(helpfile) return display_extra_help def update_recent_files_list(self, new_file=None): "Load and update the recent files list and menus" rf_list = [] if os.path.exists(self.recent_files_path): with open(self.recent_files_path, 'r') as rf_list_file: rf_list = rf_list_file.readlines() if new_file: new_file = os.path.abspath(new_file) + '\n' if new_file in rf_list: rf_list.remove(new_file) # move to top rf_list.insert(0, new_file) # clean and save the recent files list bad_paths = [] for path in rf_list: if '\0' in path or not os.path.exists(path[0:-1]): bad_paths.append(path) rf_list = [path for path in rf_list if path not in bad_paths] ulchars = "1234567890ABCDEFGHIJK" rf_list = rf_list[0:len(ulchars)] try: with open(self.recent_files_path, 'w') as rf_file: rf_file.writelines(rf_list) except IOError as err: if not getattr(self.root, "recentfilelist_error_displayed", False): self.root.recentfilelist_error_displayed = True tkMessageBox.showerror(title='IDLE Error', message='Unable to update Recent Files list:\n%s' % str(err), parent=self.text) # for each edit window instance, construct the recent files menu for instance in self.top.instance_dict.keys(): menu = instance.recent_files_menu menu.delete(0, END) # clear, and rebuild: for i, file_name in enumerate(rf_list): file_name = file_name.rstrip() # zap \n # make unicode string to display non-ASCII chars correctly ufile_name = self._filename_to_unicode(file_name) callback = instance.__recent_file_callback(file_name) menu.add_command(label=ulchars[i] + " " + ufile_name, command=callback, underline=0) def __recent_file_callback(self, file_name): def open_recent_file(fn_closure=file_name): self.io.open(editFile=fn_closure) return open_recent_file def saved_change_hook(self): short = self.short_title() long = self.long_title() if short and long: title = short + " - " + long + _py_version elif short: title = short elif long: title = long else: title = "Untitled" icon = short or long or title if not self.get_saved(): title = "*%s*" % title icon = "*%s" % icon self.top.wm_title(title) self.top.wm_iconname(icon) def get_saved(self): return self.undo.get_saved() def set_saved(self, flag): self.undo.set_saved(flag) def reset_undo(self): self.undo.reset_undo() def short_title(self): filename = self.io.filename if filename: filename = os.path.basename(filename) else: filename = "Untitled" # return unicode string to display non-ASCII chars correctly return self._filename_to_unicode(filename) def long_title(self): # return unicode string to display non-ASCII chars correctly return self._filename_to_unicode(self.io.filename or "") def center_insert_event(self, event): self.center() def center(self, mark="insert"): text = self.text top, bot = self.getwindowlines() lineno = self.getlineno(mark) height = bot - top newtop = max(1, lineno - height//2) text.yview(float(newtop)) def getwindowlines(self): text = self.text top = self.getlineno("@0,0") bot = self.getlineno("@0,65535") if top == bot and text.winfo_height() == 1: # Geometry manager hasn't run yet height = int(text['height']) bot = top + height - 1 return top, bot def getlineno(self, mark="insert"): text = self.text return int(float(text.index(mark))) def get_geometry(self): "Return (width, height, x, y)" geom = self.top.wm_geometry() m = re.match(r"(\d+)x(\d+)\+(-?\d+)\+(-?\d+)", geom) tuple = (map(int, m.groups())) return tuple def close_event(self, event): self.close() def maybesave(self): if self.io: if not self.get_saved(): if self.top.state()!='normal': self.top.deiconify() self.top.lower() self.top.lift() return self.io.maybesave() def close(self): reply = self.maybesave() if str(reply) != "cancel": self._close() return reply def _close(self): if self.io.filename: self.update_recent_files_list(new_file=self.io.filename) WindowList.unregister_callback(self.postwindowsmenu) self.unload_extensions() self.io.close() self.io = None self.undo = None if self.color: self.color.close(False) self.color = None self.text = None self.tkinter_vars = None self.per.close() self.per = None self.top.destroy() if self.close_hook: # unless override: unregister from flist, terminate if last window self.close_hook() def load_extensions(self): self.extensions = {} self.load_standard_extensions() def unload_extensions(self): for ins in self.extensions.values(): if hasattr(ins, "close"): ins.close() self.extensions = {} def load_standard_extensions(self): for name in self.get_standard_extension_names(): try: self.load_extension(name) except: print "Failed to load extension", repr(name) import traceback traceback.print_exc() def get_standard_extension_names(self): return idleConf.GetExtensions(editor_only=True) def load_extension(self, name): try: mod = __import__(name, globals(), locals(), []) except ImportError: print "\nFailed to import extension: ", name return cls = getattr(mod, name) keydefs = idleConf.GetExtensionBindings(name) if hasattr(cls, "menudefs"): self.fill_menus(cls.menudefs, keydefs) ins = cls(self) self.extensions[name] = ins if keydefs: self.apply_bindings(keydefs) for vevent in keydefs.keys(): methodname = vevent.replace("-", "_") while methodname[:1] == '<': methodname = methodname[1:] while methodname[-1:] == '>': methodname = methodname[:-1] methodname = methodname + "_event" if hasattr(ins, methodname): self.text.bind(vevent, getattr(ins, methodname)) def apply_bindings(self, keydefs=None): if keydefs is None: keydefs = self.Bindings.default_keydefs text = self.text text.keydefs = keydefs for event, keylist in keydefs.items(): if keylist: text.event_add(event, *keylist) def fill_menus(self, menudefs=None, keydefs=None): """Add appropriate entries to the menus and submenus Menus that are absent or None in self.menudict are ignored. """ if menudefs is None: menudefs = self.Bindings.menudefs if keydefs is None: keydefs = self.Bindings.default_keydefs menudict = self.menudict text = self.text for mname, entrylist in menudefs: menu = menudict.get(mname) if not menu: continue for entry in entrylist: if not entry: menu.add_separator() else: label, eventname = entry checkbutton = (label[:1] == '!') if checkbutton: label = label[1:] underline, label = prepstr(label) accelerator = get_accelerator(keydefs, eventname) def command(text=text, eventname=eventname): text.event_generate(eventname) if checkbutton: var = self.get_var_obj(eventname, BooleanVar) menu.add_checkbutton(label=label, underline=underline, command=command, accelerator=accelerator, variable=var) else: menu.add_command(label=label, underline=underline, command=command, accelerator=accelerator) def getvar(self, name): var = self.get_var_obj(name) if var: value = var.get() return value else: raise NameError, name def setvar(self, name, value, vartype=None): var = self.get_var_obj(name, vartype) if var: var.set(value) else: raise NameError, name def get_var_obj(self, name, vartype=None): var = self.tkinter_vars.get(name) if not var and vartype: # create a Tkinter variable object with self.text as master: self.tkinter_vars[name] = var = vartype(self.text) return var # Tk implementations of "virtual text methods" -- each platform # reusing IDLE's support code needs to define these for its GUI's # flavor of widget. # Is character at text_index in a Python string? Return 0 for # "guaranteed no", true for anything else. This info is expensive # to compute ab initio, but is probably already known by the # platform's colorizer. def is_char_in_string(self, text_index): if self.color: # Return true iff colorizer hasn't (re)gotten this far # yet, or the character is tagged as being in a string return self.text.tag_prevrange("TODO", text_index) or \ "STRING" in self.text.tag_names(text_index) else: # The colorizer is missing: assume the worst return 1 # If a selection is defined in the text widget, return (start, # end) as Tkinter text indices, otherwise return (None, None) def get_selection_indices(self): try: first = self.text.index("sel.first") last = self.text.index("sel.last") return first, last except TclError: return None, None # Return the text widget's current view of what a tab stop means # (equivalent width in spaces). def get_tabwidth(self): current = self.text['tabs'] or TK_TABWIDTH_DEFAULT return int(current) # Set the text widget's current view of what a tab stop means. def set_tabwidth(self, newtabwidth): text = self.text if self.get_tabwidth() != newtabwidth: pixels = text.tk.call("font", "measure", text["font"], "-displayof", text.master, "n" * newtabwidth) text.configure(tabs=pixels) # If ispythonsource and guess are true, guess a good value for # indentwidth based on file content (if possible), and if # indentwidth != tabwidth set usetabs false. # In any case, adjust the Text widget's view of what a tab # character means. def set_indentation_params(self, ispythonsource, guess=True): if guess and ispythonsource: i = self.guess_indent() if 2 <= i <= 8: self.indentwidth = i if self.indentwidth != self.tabwidth: self.usetabs = False self.set_tabwidth(self.tabwidth) def smart_backspace_event(self, event): text = self.text first, last = self.get_selection_indices() if first and last: text.delete(first, last) text.mark_set("insert", first) return "break" # Delete whitespace left, until hitting a real char or closest # preceding virtual tab stop. chars = text.get("insert linestart", "insert") if chars == '': if text.compare("insert", ">", "1.0"): # easy: delete preceding newline text.delete("insert-1c") else: text.bell() # at start of buffer return "break" if chars[-1] not in " \t": # easy: delete preceding real char text.delete("insert-1c") return "break" # Ick. It may require *inserting* spaces if we back up over a # tab character! This is written to be clear, not fast. tabwidth = self.tabwidth have = len(chars.expandtabs(tabwidth)) assert have > 0 want = ((have - 1) // self.indentwidth) * self.indentwidth # Debug prompt is multilined.... if self.context_use_ps1: last_line_of_prompt = sys.ps1.split('\n')[-1] else: last_line_of_prompt = '' ncharsdeleted = 0 while 1: if chars == last_line_of_prompt: break chars = chars[:-1] ncharsdeleted = ncharsdeleted + 1 have = len(chars.expandtabs(tabwidth)) if have <= want or chars[-1] not in " \t": break text.undo_block_start() text.delete("insert-%dc" % ncharsdeleted, "insert") if have < want: text.insert("insert", ' ' * (want - have)) text.undo_block_stop() return "break" def smart_indent_event(self, event): # if intraline selection: # delete it # elif multiline selection: # do indent-region # else: # indent one level text = self.text first, last = self.get_selection_indices() text.undo_block_start() try: if first and last: if index2line(first) != index2line(last): return self.indent_region_event(event) text.delete(first, last) text.mark_set("insert", first) prefix = text.get("insert linestart", "insert") raw, effective = classifyws(prefix, self.tabwidth) if raw == len(prefix): # only whitespace to the left self.reindent_to(effective + self.indentwidth) else: # tab to the next 'stop' within or to right of line's text: if self.usetabs: pad = '\t' else: effective = len(prefix.expandtabs(self.tabwidth)) n = self.indentwidth pad = ' ' * (n - effective % n) text.insert("insert", pad) text.see("insert") return "break" finally: text.undo_block_stop() def newline_and_indent_event(self, event): text = self.text first, last = self.get_selection_indices() text.undo_block_start() try: if first and last: text.delete(first, last) text.mark_set("insert", first) line = text.get("insert linestart", "insert") i, n = 0, len(line) while i < n and line[i] in " \t": i = i+1 if i == n: # the cursor is in or at leading indentation in a continuation # line; just inject an empty line at the start text.insert("insert linestart", '\n') return "break" indent = line[:i] # strip whitespace before insert point unless it's in the prompt i = 0 last_line_of_prompt = sys.ps1.split('\n')[-1] while line and line[-1] in " \t" and line != last_line_of_prompt: line = line[:-1] i = i+1 if i: text.delete("insert - %d chars" % i, "insert") # strip whitespace after insert point while text.get("insert") in " \t": text.delete("insert") # start new line text.insert("insert", '\n') # adjust indentation for continuations and block # open/close first need to find the last stmt lno = index2line(text.index('insert')) y = PyParse.Parser(self.indentwidth, self.tabwidth) if not self.context_use_ps1: for context in self.num_context_lines: startat = max(lno - context, 1) startatindex = repr(startat) + ".0" rawtext = text.get(startatindex, "insert") y.set_str(rawtext) bod = y.find_good_parse_start( self.context_use_ps1, self._build_char_in_string_func(startatindex)) if bod is not None or startat == 1: break y.set_lo(bod or 0) else: r = text.tag_prevrange("console", "insert") if r: startatindex = r[1] else: startatindex = "1.0" rawtext = text.get(startatindex, "insert") y.set_str(rawtext) y.set_lo(0) c = y.get_continuation_type() if c != PyParse.C_NONE: # The current stmt hasn't ended yet. if c == PyParse.C_STRING_FIRST_LINE: # after the first line of a string; do not indent at all pass elif c == PyParse.C_STRING_NEXT_LINES: # inside a string which started before this line; # just mimic the current indent text.insert("insert", indent) elif c == PyParse.C_BRACKET: # line up with the first (if any) element of the # last open bracket structure; else indent one # level beyond the indent of the line with the # last open bracket self.reindent_to(y.compute_bracket_indent()) elif c == PyParse.C_BACKSLASH: # if more than one line in this stmt already, just # mimic the current indent; else if initial line # has a start on an assignment stmt, indent to # beyond leftmost =; else to beyond first chunk of # non-whitespace on initial line if y.get_num_lines_in_stmt() > 1: text.insert("insert", indent) else: self.reindent_to(y.compute_backslash_indent()) else: assert 0, "bogus continuation type %r" % (c,) return "break" # This line starts a brand new stmt; indent relative to # indentation of initial line of closest preceding # interesting stmt. indent = y.get_base_indent_string() text.insert("insert", indent) if y.is_block_opener(): self.smart_indent_event(event) elif indent and y.is_block_closer(): self.smart_backspace_event(event) return "break" finally: text.see("insert") text.undo_block_stop() # Our editwin provides a is_char_in_string function that works # with a Tk text index, but PyParse only knows about offsets into # a string. This builds a function for PyParse that accepts an # offset. def _build_char_in_string_func(self, startindex): def inner(offset, _startindex=startindex, _icis=self.is_char_in_string): return _icis(_startindex + "+%dc" % offset) return inner def indent_region_event(self, event): head, tail, chars, lines = self.get_region() for pos in range(len(lines)): line = lines[pos] if line: raw, effective = classifyws(line, self.tabwidth) effective = effective + self.indentwidth lines[pos] = self._make_blanks(effective) + line[raw:] self.set_region(head, tail, chars, lines) return "break" def dedent_region_event(self, event): head, tail, chars, lines = self.get_region() for pos in range(len(lines)): line = lines[pos] if line: raw, effective = classifyws(line, self.tabwidth) effective = max(effective - self.indentwidth, 0) lines[pos] = self._make_blanks(effective) + line[raw:] self.set_region(head, tail, chars, lines) return "break" def comment_region_event(self, event): head, tail, chars, lines = self.get_region() for pos in range(len(lines) - 1): line = lines[pos] lines[pos] = '##' + line self.set_region(head, tail, chars, lines) def uncomment_region_event(self, event): head, tail, chars, lines = self.get_region() for pos in range(len(lines)): line = lines[pos] if not line: continue if line[:2] == '##': line = line[2:] elif line[:1] == '#': line = line[1:] lines[pos] = line self.set_region(head, tail, chars, lines) def tabify_region_event(self, event): head, tail, chars, lines = self.get_region() tabwidth = self._asktabwidth() if tabwidth is None: return for pos in range(len(lines)): line = lines[pos] if line: raw, effective = classifyws(line, tabwidth) ntabs, nspaces = divmod(effective, tabwidth) lines[pos] = '\t' * ntabs + ' ' * nspaces + line[raw:] self.set_region(head, tail, chars, lines) def untabify_region_event(self, event): head, tail, chars, lines = self.get_region() tabwidth = self._asktabwidth() if tabwidth is None: return for pos in range(len(lines)): lines[pos] = lines[pos].expandtabs(tabwidth) self.set_region(head, tail, chars, lines) def toggle_tabs_event(self, event): if self.askyesno( "Toggle tabs", "Turn tabs " + ("on", "off")[self.usetabs] + "?\nIndent width " + ("will be", "remains at")[self.usetabs] + " 8." + "\n Note: a tab is always 8 columns", parent=self.text): self.usetabs = not self.usetabs # Try to prevent inconsistent indentation. # User must change indent width manually after using tabs. self.indentwidth = 8 return "break" # XXX this isn't bound to anything -- see tabwidth comments ## def change_tabwidth_event(self, event): ## new = self._asktabwidth() ## if new != self.tabwidth: ## self.tabwidth = new ## self.set_indentation_params(0, guess=0) ## return "break" def change_indentwidth_event(self, event): new = self.askinteger( "Indent width", "New indent width (2-16)\n(Always use 8 when using tabs)", parent=self.text, initialvalue=self.indentwidth, minvalue=2, maxvalue=16) if new and new != self.indentwidth and not self.usetabs: self.indentwidth = new return "break" def get_region(self): text = self.text first, last = self.get_selection_indices() if first and last: head = text.index(first + " linestart") tail = text.index(last + "-1c lineend +1c") else: head = text.index("insert linestart") tail = text.index("insert lineend +1c") chars = text.get(head, tail) lines = chars.split("\n") return head, tail, chars, lines def set_region(self, head, tail, chars, lines): text = self.text newchars = "\n".join(lines) if newchars == chars: text.bell() return text.tag_remove("sel", "1.0", "end") text.mark_set("insert", head) text.undo_block_start() text.delete(head, tail) text.insert(head, newchars) text.undo_block_stop() text.tag_add("sel", head, "insert") # Make string that displays as n leading blanks. def _make_blanks(self, n): if self.usetabs: ntabs, nspaces = divmod(n, self.tabwidth) return '\t' * ntabs + ' ' * nspaces else: return ' ' * n # Delete from beginning of line to insert point, then reinsert # column logical (meaning use tabs if appropriate) spaces. def reindent_to(self, column): text = self.text text.undo_block_start() if text.compare("insert linestart", "!=", "insert"): text.delete("insert linestart", "insert") if column: text.insert("insert", self._make_blanks(column)) text.undo_block_stop() def _asktabwidth(self): return self.askinteger( "Tab width", "Columns per tab? (2-16)", parent=self.text, initialvalue=self.indentwidth, minvalue=2, maxvalue=16) # Guess indentwidth from text content. # Return guessed indentwidth. This should not be believed unless # it's in a reasonable range (e.g., it will be 0 if no indented # blocks are found). def guess_indent(self): opener, indented = IndentSearcher(self.text, self.tabwidth).run() if opener and indented: raw, indentsmall = classifyws(opener, self.tabwidth) raw, indentlarge = classifyws(indented, self.tabwidth) else: indentsmall = indentlarge = 0 return indentlarge - indentsmall # "line.col" -> line, as an int def index2line(index): return int(float(index)) # Look at the leading whitespace in s. # Return pair (# of leading ws characters, # effective # of leading blanks after expanding # tabs to width tabwidth) def classifyws(s, tabwidth): raw = effective = 0 for ch in s: if ch == ' ': raw = raw + 1 effective = effective + 1 elif ch == '\t': raw = raw + 1 effective = (effective // tabwidth + 1) * tabwidth else: break return raw, effective import tokenize _tokenize = tokenize del tokenize class IndentSearcher(object): # .run() chews over the Text widget, looking for a block opener # and the stmt following it. Returns a pair, # (line containing block opener, line containing stmt) # Either or both may be None. def __init__(self, text, tabwidth): self.text = text self.tabwidth = tabwidth self.i = self.finished = 0 self.blkopenline = self.indentedline = None def readline(self): if self.finished: return "" i = self.i = self.i + 1 mark = repr(i) + ".0" if self.text.compare(mark, ">=", "end"): return "" return self.text.get(mark, mark + " lineend+1c") def tokeneater(self, type, token, start, end, line, INDENT=_tokenize.INDENT, NAME=_tokenize.NAME, OPENERS=('class', 'def', 'for', 'if', 'try', 'while')): if self.finished: pass elif type == NAME and token in OPENERS: self.blkopenline = line elif type == INDENT and self.blkopenline: self.indentedline = line self.finished = 1 def run(self): save_tabsize = _tokenize.tabsize _tokenize.tabsize = self.tabwidth try: try: _tokenize.tokenize(self.readline, self.tokeneater) except (_tokenize.TokenError, SyntaxError): # since we cut off the tokenizer early, we can trigger # spurious errors pass finally: _tokenize.tabsize = save_tabsize return self.blkopenline, self.indentedline ### end autoindent code ### def prepstr(s): # Helper to extract the underscore from a string, e.g. # prepstr("Co_py") returns (2, "Copy"). i = s.find('_') if i >= 0: s = s[:i] + s[i+1:] return i, s keynames = { 'bracketleft': '[', 'bracketright': ']', 'slash': '/', } def get_accelerator(keydefs, eventname): keylist = keydefs.get(eventname) # issue10940: temporary workaround to prevent hang with OS X Cocoa Tk 8.5 # if not keylist: if (not keylist) or (macosxSupport.isCocoaTk() and eventname in { "<<open-module>>", "<<goto-line>>", "<<change-indentwidth>>"}): return "" s = keylist[0] s = re.sub(r"-[a-z]\b", lambda m: m.group().upper(), s) s = re.sub(r"\b\w+\b", lambda m: keynames.get(m.group(), m.group()), s) s = re.sub("Key-", "", s) s = re.sub("Cancel","Ctrl-Break",s) # [email protected] s = re.sub("Control-", "Ctrl-", s) s = re.sub("-", "+", s) s = re.sub("><", " ", s) s = re.sub("<", "", s) s = re.sub(">", "", s) return s def fixwordbreaks(root): # Make sure that Tk's double-click and next/previous word # operations use our definition of a word (i.e. an identifier) tk = root.tk tk.call('tcl_wordBreakAfter', 'a b', 0) # make sure word.tcl is loaded tk.call('set', 'tcl_wordchars', '[a-zA-Z0-9_]') tk.call('set', 'tcl_nonwordchars', '[^a-zA-Z0-9_]') def _editor_window(parent): # htest # # error if close master window first - timer event, after script root = parent fixwordbreaks(root) if sys.argv[1:]: filename = sys.argv[1] else: filename = None macosxSupport.setupApp(root, None) edit = EditorWindow(root=root, filename=filename) edit.text.bind("<<close-all-windows>>", edit.close_event) # Does not stop error, neither does following # edit.text.bind("<<close-window>>", edit.close_event) if __name__ == '__main__': from idlelib.idle_test.htest import run run(_help_dialog, _editor_window)<|fim▁end|>
<|file_name|>forms.py<|end_file_name|><|fim▁begin|>"""Forms to render HTML input & validate request data.""" from wtforms import Form, BooleanField, DateTimeField, PasswordField from wtforms import TextAreaField, TextField from wtforms.validators import Length, required class AppointmentForm(Form): """Render HTML input for Appointment model & validate submissions. This matches the models.Appointment class very closely. Where models.Appointment represents the domain and its persistence, this class represents how to display a form in HTML & accept/reject the results. """ title = TextField('Title', [Length(max=255)]) start = DateTimeField('Start', [required()])<|fim▁hole|> end = DateTimeField('End') allday = BooleanField('All Day') location = TextField('Location', [Length(max=255)]) description = TextAreaField('Description') class LoginForm(Form): """Render HTML input for user login form. Authentication (i.e. password verification) happens in the view function. """ username = TextField('Username', [required()]) password = PasswordField('Password', [required()])<|fim▁end|>
<|file_name|>traceback.rs<|end_file_name|><|fim▁begin|>use std::default::Default; use std::iter; use std::marker::PhantomData; use std::ops::Range; use crate::alignment::AlignmentOperation; use crate::pattern_matching::myers::{word_size, BitVec, DistType, State}; /// Objects implementing this trait handle the addition of calculated blocks (State<T, D>) /// to a container, and are responsible for creating the respective `TracebackHandler` object. pub(super) trait StatesHandler<'a, T, D> where T: BitVec + 'a, D: DistType, { /// Object that helps obtaining a single traceback path type TracebackHandler: TracebackHandler<'a, T, D>; /// Type that represents a column in the traceback matrix type TracebackColumn: ?Sized; /// Prepare for a new search given n (maximum expected number of traceback columns) and /// m (pattern length). /// Returns the expected size of the vector storing the calculated blocks given this /// information. The vector will then be initialized with the given number of 'empty' /// State<T, D> objects and supplied to the other methods as slice. fn init(&mut self, n: usize, m: D) -> usize; /// Fill the column at `pos` with states initialized with the maximum distance /// (`State::max()`). fn set_max_state(&self, pos: usize, states: &mut [State<T, D>]); /// This method copies over all blocks (or the one block) from a tracback column /// into the mutable `states` slice at the given column position. fn add_state(&self, source: &Self::TracebackColumn, pos: usize, states: &mut [State<T, D>]); /// Initiates a `TracebackHandler` object to assist with a traceback, 'starting' /// at the given end position. fn init_traceback(&self, m: D, pos: usize, states: &'a [State<T, D>]) -> Self::TracebackHandler; } /// Objects implementing this trait should store states and have methods /// necessary for obtaining a single traceback path. This allows to use the /// same traceback code for the simple and the block-based Myers pattern /// matching approaches. It is designed to be as general as possible /// to allow different implementations. /// /// Implementors of `TracebackHandler` keep two `State<T, D>` instances, /// which store the information from two horizontally adjacent traceback /// columns, encoded in the PV / MV bit vectors. The columns are accessible /// using the methods `block()` (current / right column) and `left_block()` /// (left column). Moving horizontally to the next position can be achieved /// using `move_left()`. /// /// Implementors also track the vertical cursor positions within the current /// traceback columns (two separate cursors for left and right column). /// `block()` and `left_block()` will always return the block that currently /// contain the cursors. /// `pos_bitvec()` returns a bit vector with a single activated bit at the current /// vertical position within the *right (current)* column. /// Moving to the next vertical position is achieved by `move_up()` and /// `move_up_left()`. With the block based implementation, this may involve /// switching to a new block. pub(super) trait TracebackHandler<'a, T, D> where T: BitVec + 'a, D: DistType, { /// Returns a reference to the current (right) block. fn block(&self) -> &State<T, D>; /// Returns a mutable reference to the current (right) block. fn block_mut(&mut self) -> &mut State<T, D>; /// Returns a reference to the left block. fn left_block(&self) -> &State<T, D>; /// Returns a mutable reference to the left block. fn left_block_mut(&mut self) -> &mut State<T, D>; /// Bit vector representing the position in the traceback. Only the bit /// at the current position should be on. /// For a search pattern of length 4, the initial bit vector would be /// `0b1000`. A call to `move_up_cursor()` will shift the vector, so another /// call to `pos_bitvec()` results in `0b100`. /// The bit vector has a width of `T`, meaning that it can store /// the same number of positions as the PV and MV vectors. In the /// case of the block based algorithm, the vector only stores the /// position within the current block. fn pos_bitvec(&self) -> T; /// Move up cursor by one position in traceback matrix. /// /// # Arguments /// /// * adjust_dist: If true, the distance score of the block is adjusted /// based on the current cursor position before moving it up. /// *Note concerning the block based Myers algorithm:* /// The the active bit in bit vector returned by `pos_bitvec()` /// is expected to jump back to the maximum (lowest) position /// when reaching the uppermost position (like `rotate_right()` does). fn move_up(&mut self, adjust_dist: bool); /// Move up left cursor by one position in traceback matrix. /// /// # Arguments /// /// * adjust_dist: If true, the distance score of the block is adjusted /// based on the current cursor position before moving it up. /// However, the current cursor position of the **right** block is used, /// **not** the one of the left block. This is an important oddity, which /// makes only sense because of the design of the traceback algorithm. fn move_up_left(&mut self, adjust_dist: bool); /// Shift the view by one traceback column / block to the left. The /// block that was on the left position previously moves to the right / /// current block without changes. The cursor positions have to be /// adjusted indepentedently if necessary using `move_up(false)` / /// `move_up_left(false)`. /// `move_left()` adjusts distance score of the new left block to /// be correct for the left vertical cursor position. It is therefore /// important that the cursor is moved *before* calling `move_left()`. fn move_to_left(&mut self); /// Rather specialized method that allows having a simpler code in Traceback::_traceback_at() /// Checks if the position below the left cursor has a smaller distance, and if so, /// moves the cursor to this block and returns `true`. /// /// The problem is that the current implementation always keeps the left cursor in the /// diagonal position for performance reasons. In this case, checking the actual left /// distance score can be complicated with the block-based algorithm since the left cursor /// may be at the lower block boundary. If so, the function thus has to check the topmost /// position of the lower block and keep this block if the distance is better (lower). fn move_left_down_if_better(&mut self) -> bool; /// Returns a slice containing all blocks of the current traceback column /// from top to bottom. Used for debugging only. fn column_slice(&self) -> &[State<T, D>]; /// Returns true if topmost position in the traceback matrix has been reached, /// meaning that the traceback is complete. /// Technically this means, that `move_up_cursor()` was called so many times /// until the uppermost block was reached and the pos_bitvec() does not contain /// any bit, since shifting has removed it from the vector. fn finished(&self) -> bool; /// For debugging only fn print_state(&self) { println!( "--- TB dist ({:?} <-> {:?})", self.left_block().dist, self.block().dist ); println!( "{:064b} m\n{:064b} + ({:?}) (left) d={:?}\n{:064b} - ({:?})\n \ {:064b} + ({:?}) (current) d={:?}\n{:064b} - ({:?})\n", self.pos_bitvec(), self.left_block().pv, self.left_block().pv, self.left_block().dist, self.left_block().mv, self.left_block().mv, self.block().pv, self.block().pv, self.block().dist, self.block().mv, self.block().mv ); } } pub(super) struct Traceback<'a, T, D, H> where T: BitVec + 'a, D: DistType, H: StatesHandler<'a, T, D>, { m: D, positions: iter::Cycle<Range<usize>>, handler: H, pos: usize, _t: PhantomData<&'a T>, } impl<'a, T, D, H> Traceback<'a, T, D, H> where T: BitVec,<|fim▁hole|> D: DistType, H: StatesHandler<'a, T, D>, { #[inline] pub fn new( states: &mut Vec<State<T, D>>, initial_state: &H::TracebackColumn, num_cols: usize, m: D, mut handler: H, ) -> Self { // Correct traceback needs two additional columns at the left of the matrix (see below). // Therefore reserving additional space. let num_cols = num_cols + 2; let n_states = handler.init(num_cols, m); let mut tb = Traceback { m, positions: (0..num_cols).cycle(), handler, pos: 0, _t: PhantomData, }; // extend or truncate states vector let curr_len = states.len(); if n_states > curr_len { states.reserve(n_states); states.extend((0..n_states - curr_len).map(|_| State::default())); } else { states.truncate(n_states); states.shrink_to_fit(); } // important if using unsafe in add_state(), and also for correct functioning of traceback debug_assert!(states.len() == n_states); // first column is used to ensure a correct path if the text (target) // is shorter than the pattern (query) tb.pos = tb.positions.next().unwrap(); tb.handler.set_max_state(tb.pos, states); // initial state tb.add_state(initial_state, states); tb } #[inline] pub fn add_state(&mut self, column: &H::TracebackColumn, states: &mut [State<T, D>]) { self.pos = self.positions.next().unwrap(); self.handler.add_state(column, self.pos, states); } /// Returns the length of the current match, optionally adding the /// alignment path to `ops` #[inline] pub fn traceback( &self, ops: Option<&mut Vec<AlignmentOperation>>, states: &'a [State<T, D>], ) -> (D, D) { self._traceback_at(self.pos, ops, states) } /// Returns the length of a match with a given end position, optionally adding the /// alignment path to `ops` /// only to be called if the `states` vec contains all states of the text #[inline] pub fn traceback_at( &self, pos: usize, ops: Option<&mut Vec<AlignmentOperation>>, states: &'a [State<T, D>], ) -> Option<(D, D)> { let pos = pos + 2; // in order to be comparable since self.pos starts at 2, not 0 if pos <= self.pos { return Some(self._traceback_at(pos, ops, states)); } None } /// returns a tuple of alignment length and hit distance, optionally adding the alignment path /// to `ops` #[inline] fn _traceback_at( &self, pos: usize, mut ops: Option<&mut Vec<AlignmentOperation>>, state_slice: &'a [State<T, D>], ) -> (D, D) { use self::AlignmentOperation::*; // Generic object that holds the necessary data and methods let mut h = self.handler.init_traceback(self.m, pos, state_slice); // self.print_tb_matrix(pos, state_slice); let ops = &mut ops; // horizontal column offset from starting point in traceback matrix (bottom right) let mut h_offset = D::zero(); // distance of the match (will be returned) let dist = h.block().dist; // The cursor of the left state is always for diagonal position in the traceback matrix. // This allows checking for a substitution by a simple comparison. h.move_up_left(true); // Loop for finding the traceback path // If there are several possible solutions, substitutions are preferred over InDels // (Subst > Ins > Del) while !h.finished() { let op; // This loop is used to allow skipping `move_left()` using break (kind of similar // to 'goto'). This was done to avoid having to inline move_left() three times, // which would use more space. #[allow(clippy::never_loop)] loop { // h.print_state(); if h.left_block().dist.wrapping_add(&D::one()) == h.block().dist { // Diagonal (substitution) // Since the left cursor is always in the upper diagonal position, // a simple comparison of distances is enough to determine substitutions. h.move_up(false); h.move_up_left(false); op = Subst; } else if h.block().pv & h.pos_bitvec() != T::zero() { // Up h.move_up(true); h.move_up_left(true); op = Ins; break; } else if h.move_left_down_if_better() { // Left op = Del; } else { // Diagonal (match) h.move_up(false); h.move_up_left(false); op = Match; } // Moving one position to the left, adjusting h_offset h_offset += D::one(); h.move_to_left(); break; } // println!("{:?}", op); if let Some(o) = ops.as_mut() { o.push(op); } } (h_offset, dist) } // Useful for debugging #[allow(dead_code)] fn print_tb_matrix(&self, pos: usize, state_slice: &'a [State<T, D>]) { let mut h = self.handler.init_traceback(self.m, pos, state_slice); let m = self.m.to_usize().unwrap(); let mut out = vec![]; for _ in 0..state_slice.len() { let mut col_out = vec![]; let mut empty = true; for (i, state) in h.column_slice().iter().enumerate().rev() { if !(state.is_new() || state.is_max()) { empty = false; } let w = word_size::<T>(); let end = (i + 1) * w; let n = if end <= m { w } else { m % w }; state.write_dist_column(n, &mut col_out); } out.push(col_out); h.move_to_left(); if empty { break; } } for j in (0..m).rev() { print!("{:>4}: ", m - j + 1); for col in out.iter().rev() { if let Some(d) = col.get(j) { if *d >= (D::max_value() >> 1) { // missing value print!(" "); } else { print!("{:>4?}", d); } } else { print!(" -"); } } println!(); } } }<|fim▁end|>
<|file_name|>foreign-link-switcher.ts<|end_file_name|><|fim▁begin|>export class ForeignLinkSwitcher { private static instance: ForeignLinkSwitcher; private static initPage = location.href; foreignLinkCheckbox = document.getElementById('has_foreign_link') as HTMLInputElement; foreignLinkSwitchedEl = document.getElementById('event_foreign_link_box') as HTMLDivElement; foreignLinkInput = document.getElementById('event_foreign_link') as HTMLInputElement; static init() { if (!ForeignLinkSwitcher.instance || ForeignLinkSwitcher.initPage !== location.href) { ForeignLinkSwitcher.initPage = location.href; ForeignLinkSwitcher.instance = new ForeignLinkSwitcher(); document.addEventListener('turbolinks:request-start', (_: Event) => { ForeignLinkSwitcher.initPage = null; }); } return ForeignLinkSwitcher.instance; }<|fim▁hole|> return this.foreignLinkCheckbox.checked; } private constructor() { if (this.isChecked) this.foreignLinkSwitchedEl.classList.remove('hidden'); this.bindEvents(); } bindEvents() { this.foreignLinkCheckbox.addEventListener('change', (_: Event) => { this.foreignLinkSwitchedEl.classList.toggle('hidden'); if (!this.isChecked) { this.foreignLinkInput.value = ''; this.foreignLinkInput.setAttribute('disable', 'disabled'); } else { this.foreignLinkInput.removeAttribute('disabled'); } }); } }<|fim▁end|>
private get isChecked(): boolean {
<|file_name|>ss-elements.module.ts<|end_file_name|><|fim▁begin|>// //import { AeChartComponent } from './ae-chart/ae-chart.component'; // import { RouterModule } from '@angular/router'; // // import { AeLegendComponent } from './ae-legend/ae-legend.component'; // // import { AeIndicatorComponent } from './ae-indicator/ae-indicator.component'; // // import { AeBadgeComponent } from './ae-badge/ae-badge.component'; // // import { GroupByPipe } from '../atlas-shared/pipes/groupby-pipe'; // // import { IBreadcrumb } from './common/models/ae-ibreadcrumb.model'; // // import { BreadcrumbService } from './common/services/breadcrumb-service'; // import { FormsModule, ReactiveFormsModule } from '@angular/forms'; // import { ErrorHandler, NgModule } from '@angular/core'; // import { CommonModule } from '@angular/common'; // // import { AeInputComponent } from './ae-input/ae-input.component'; // // import { AeCheckboxComponent } from './ae-checkbox/ae-checkbox.component'; // // import { AtlasErrorHandler } from '../shared/error-handling/atlas-error-handler';<|fim▁hole|>// // import { AeAnchorComponent } from './ae-anchor/ae-anchor.component'; // // import { AeSwitchComponent } from './ae-switch/ae-switch.component'; // // import { AeLoaderComponent } from './ae-loader/ae-loader.component'; // // import { AeTextareaComponent } from './ae-textarea/ae-textarea.component'; // // import { AeListComponent } from './ae-list/ae-list.component'; // // import { AeIconComponent } from './ae-icon/ae-icon.component'; // // import { AeStatisticComponent } from './ae-statistic/ae-statistic.component'; // // import { AeRadioButtonComponent } from './ae-radiobutton/ae-radiobutton.component'; // // import { AePaginationComponent } from "./ae-pagination/ae-pagination.component"; // // import { AeRadioGroupComponent } from './ae-radio-group/ae-radio-group.component'; // // import { AeBannerComponent } from './ae-banner/ae-banner.component'; // // import { AeSplitbuttonComponent } from './ae-splitbutton/ae-splitbutton.component'; // // import { AePopoverComponent } from './ae-popover/ae-popover.component'; // // import { AeTabComponent } from './ae-tab/ae-tab.component'; // // import { AeTabStripComponent } from './ae-tabstrip/ae-tabstrip.component'; // // import { AeAutocompleteComponent } from './ae-autocomplete/ae-autocomplete.component'; // // import { AeHighlighttextPipe } from './common/ae-highlighttext.pipe'; // // import { AeDatetimePickerComponent } from './ae-datetime-picker/ae-datetime-picker.component'; // // import { AeFileComponent } from './ae-file/ae-file.component'; // // import { AeDatatableComponent } from './ae-datatable/ae-datatable.component'; // // import { AeColumnComponent } from './ae-datatable/ae-column/ae-column.component'; // // import { AeTemplateComponent } from './ae-template/ae-template.component'; // // import { AeVirtualListComponent } from './ae-virtual-list/ae-virtual-list.component'; // // import { AeVirtualScrollComponent } from './ae-virtual-scroll/ae-virtual-scroll.component'; // // import { AeTemplateLoaderComponent } from './ae-template-loader/ae-template-loader.component'; // // import { AeTabItemComponent } from './ae-tab/ae-tab-item/ae-tab-item.component'; // // import { AeTabStripItemComponent } from './ae-tabstrip/ae-tabstrip-item/ae-tabstrip-item.component'; // import { AeMessageComponent } from './ae-message/ae-message.component'; // // import { AeScrollDirective } from './ae-scroll/ae-scroll.directive'; // // import { AeInformationbarComponent } from './ae-informationbar/ae-informationbar.component'; // // import { AeModalDialogComponent } from './ae-modal-dialog/ae-modal-dialog.component'; // // import { AeVideoComponent } from './ae-video/ae-video.component'; // // import { AeSortListComponent } from './ae-sort-list/ae-sort-list.component'; // // import { AeFullcalendarComponent } from './ae-fullcalendar/ae-fullcalendar.component'; // // import { AeCalendarDayViewComponent } from './ae-fullcalendar/ae-calendar-day-view/ae-calendar-day-view.component'; // // import { AeCalendarMonthViewComponent } from './ae-fullcalendar/ae-calendar-month-view/ae-calendar-month-view.component'; // // import { AeCalendarWeekViewComponent } from './ae-fullcalendar/ae-calendar-week-view/ae-calendar-week-view.component'; // // import { AeCalendarMonthEventsViewComponent } from './ae-fullcalendar/ae-calendar-month-view/ae-calendar-month-events-view/ae-calendar-month-events-view.component'; // // import { AeCalendarMonthCellViewComponent } from './ae-fullcalendar/ae-calendar-month-view/ae-calendar-month-cell-view/ae-calendar-month-cell-view.component'; // // import { DragulaModule } from 'ng2-dragula/ng2-dragula'; // // import { DragulaService } from 'ng2-dragula/ng2-dragula'; // // import { AeSliderComponent } from './ae-slider/ae-slider.component'; // // import { AeCardComponent } from './ae-card/ae-card.component'; // // import { AeImageAvatarComponent } from './ae-image-avatar/ae-image-avatar.component'; // // import { AeSlideOutComponent } from './ae-slideout/ae-slideout.component'; // // import { AeBreadcrumbComponent } from './ae-breadcrumb/ae-breadcrumb.component'; // // import { Ae2BreadcrumbComponent } from './Ae2-breadcrumb/Ae2-breadcrumb.component'; // // import { AeFormComponent } from './ae-form/ae-form.component'; // // import { AeListItemComponent } from './ae-list-item/ae-list-item.component'; // // import { AeNavActionsComponent } from './ae-nav-actions/ae-nav-actions.component'; // // import { AeSnackbarComponent } from './ae-snackbar/ae-snackbar.component'; // // import { AeSignatureComponent } from './ae-signature/ae-signature.component'; // // import { SignaturePadModule } from 'angular2-signaturepad'; // @NgModule({ // imports: [ // CommonModule // , FormsModule // , ReactiveFormsModule // , DragulaModule // , ReactiveFormsModule // , RouterModule // , SignaturePadModule // ], // declarations: [ // AeInputComponent // , AeCheckboxComponent // , AeSelectComponent // , AeLabelComponent // , AeButtonComponent // , AeAnchorComponent // , AeSwitchComponent // , AeLoaderComponent // , AeTextareaComponent // , AeListComponent // , AeIconComponent // , AeStatisticComponent // , AeRadioButtonComponent // , AePaginationComponent // , AeRadioGroupComponent // , AeBannerComponent // , AeSplitbuttonComponent // , AeTabComponent // , AeTabStripComponent // , AeDatatableComponent // , AeColumnComponent // , AeTemplateComponent // , AeLoaderComponent // , AeVirtualListComponent // , AeVirtualScrollComponent // , AeTemplateLoaderComponent // , AeTabItemComponent // , AeTabStripItemComponent // , AeMessageComponent // , AeScrollDirective // , AePopoverComponent // , AeFileComponent // , AeInformationbarComponent // , AeModalDialogComponent // , AeVideoComponent // , AeSortListComponent // , AeCalendarMonthCellViewComponent // , AeCalendarMonthEventsViewComponent // , AeCalendarWeekViewComponent // , AeCalendarMonthViewComponent // , AeCalendarDayViewComponent // , AeFullcalendarComponent // , GroupByPipe // , AeDatetimePickerComponent // , AeSliderComponent // , AeCardComponent // , AeAutocompleteComponent // , AeHighlighttextPipe // , AeImageAvatarComponent // , AeSlideOutComponent // , AeBreadcrumbComponent // , AeFormComponent // , Ae2BreadcrumbComponent // , AeIndicatorComponent // , AeLegendComponent // , AeBadgeComponent // , AeListItemComponent // , AeChartComponent // , AeNavActionsComponent // , AeSnackbarComponent // , AeSignatureComponent // ], // exports: [ // AeInputComponent // , AeSelectComponent // , AeLabelComponent // , AeButtonComponent // , AeAnchorComponent // , AeCheckboxComponent // , AeSwitchComponent // , AeLoaderComponent // , AeTextareaComponent // , AeListComponent // , AeIconComponent // , AeStatisticComponent // , AeRadioButtonComponent // , AePaginationComponent // , AeRadioGroupComponent // , AeBannerComponent // , AeSplitbuttonComponent // , AeTabComponent // , AeTabStripComponent // , AeColumnComponent // , AeDatatableComponent // , AeVirtualListComponent // , AeTemplateComponent // , AeTabItemComponent // , AeTabStripItemComponent // , AeMessageComponent // , AeScrollDirective // , AePopoverComponent // , AeFileComponent // , AeInformationbarComponent // , AeModalDialogComponent // , AeVideoComponent // , AeSortListComponent // , AeCalendarMonthCellViewComponent // , AeCalendarMonthEventsViewComponent // , AeCalendarWeekViewComponent // , AeCalendarMonthViewComponent // , AeCalendarDayViewComponent // , AeFullcalendarComponent // , AeDatetimePickerComponent // , AeSliderComponent // , AeCardComponent // , AeAutocompleteComponent // , AeHighlighttextPipe // , AeImageAvatarComponent // , AeSlideOutComponent // , AeBreadcrumbComponent // , Ae2BreadcrumbComponent // , AeIndicatorComponent // , AeLegendComponent // , AeChartComponent // , AeBadgeComponent // , AeNavActionsComponent // , AeSnackbarComponent // , AeSignatureComponent // ], // providers: [ // { provide: ErrorHandler, useClass: AtlasErrorHandler } // , DragulaService, BreadcrumbService // ] // }) // export class AtlasElementsModule { // private _elementsBC: IBreadcrumb; // constructor(private _brcrumbService: BreadcrumbService) { // } // ngOnInit(): void { // this._elementsBC = { label: 'Elements', url: '/design' }; // console.log('push elements bc......'); // this._brcrumbService.add(this._elementsBC); // } // }<|fim▁end|>
// // import { AeButtonComponent } from './ae-button/ae-button.component'; // // import { AeSelectComponent } from './ae-select/ae-select.component'; // // import { AeLabelComponent } from './ae-label/ae-label.component';
<|file_name|>urls.py<|end_file_name|><|fim▁begin|># Copyright 2014 Dev in Cachu authors. All rights reserved. # Use of this source code is governed by a BSD-style<|fim▁hole|>from django.views.decorators import csrf from django.views.generic import base from django.contrib import admin admin.autodiscover() from devincachu.destaques import views as dviews from devincachu.inscricao import views as iviews from devincachu.palestras import views as pviews p = patterns urlpatterns = p("", url(r"^admin/", include(admin.site.urls)), url(r"^palestrantes/$", pviews.PalestrantesView.as_view(), name="palestrantes"), url(r"^programacao/$", pviews.ProgramacaoView.as_view(), name="programacao"), url(r"^programacao/(?P<palestrantes>.*)/(?P<slug>[\w-]+)/$", pviews.PalestraView.as_view(), name="palestra"), url(r"^inscricao/$", iviews.Inscricao.as_view(), name="inscricao"), url(r"^notificacao/$", csrf.csrf_exempt(iviews.Notificacao.as_view()), name="notificacao"), url(r"^certificado/validar/$", iviews.ValidacaoCertificado.as_view(), name="validacao_certificado"), url(r"^certificado/$", iviews.BuscarCertificado.as_view(), name="busca_certificado"), url(r"^certificado/(?P<slug>[0-9a-f]+)/$", iviews.Certificado.as_view(), name="certificado"), url(r"^sobre/$", base.TemplateView.as_view( template_name="sobre.html", ), name="sobre-o-evento"), url(r"^quando-e-onde/$", base.TemplateView.as_view( template_name="quando-e-onde.html", ), name="quando-e-onde"), url(r"^$", dviews.IndexView.as_view(), name="index"), ) if settings.DEBUG: urlpatterns += patterns("", url(r"^media/(?P<path>.*)$", "django.views.static.serve", {"document_root": settings.MEDIA_ROOT}), )<|fim▁end|>
# license that can be found in the LICENSE file. from django.conf import settings from django.conf.urls import include, patterns, url
<|file_name|>widget-form.component.ts<|end_file_name|><|fim▁begin|>import { Component, Input, Output, EventEmitter } from "@angular/core"; import { Widget } from "../../../models/widget"; interface SelectItem { value: string; label: string; } @Component({ selector: "widget-form", template: require("./widget-form.component.html"), styles: [require("./widget-form.component.scss")] }) export class WidgetFormComponent { @Input() public widget: Widget = {} as Widget; @Output() public saveWidget: EventEmitter<Widget> = new EventEmitter<Widget>(); @Output() public deleteWidget: EventEmitter<Widget> = new EventEmitter<Widget>(); @Output() public cancelWidget: EventEmitter<Widget> = new EventEmitter<Widget>(); public colors: SelectItem[] = [ { value: "red", label: "Red" }, { value: "blue", label: "Blue" }, { value: "green", label: "Green" }, { value: "orange", label: "Orange" }, { value: "yellow", label: "Yellow" }, { value: "purple", label: "Purple" } ]; public sizes: SelectItem[] = [ { value: "tiny", label: "Tiny" }, { value: "small", label: "Small" }, { value: "medium", label: "Medium" }, { value: "large", label: "Large" }, { value: "huge", label: "Huge" } ]; public saveWidgetButton(widget: Widget) { this.saveWidget.emit(widget); } public deleteWidgetButton(widget: Widget) { this.deleteWidget.emit(widget); } public cancelWidgetButton(widget: Widget) { this.cancelWidget.emit(widget); }<|fim▁hole|><|fim▁end|>
}
<|file_name|>ko.js<|end_file_name|><|fim▁begin|>var Lang = {}; Lang.category = { "name": "ko" }; Lang.type = "ko"; Lang.en = "English"; Lang.Command = { "101": "블록 쓰레드 추가하기", "102": "블록 쓰레드 삭제하기", "103": "블록 삭제하기", "104": "블록 복구하기", "105": "블록 끼워넣기", "106": "블록 분리하기", "107": "블록 이동하기", "108": "블록 복제하기", "109": "블록 복제 취소하기", "110": "스크롤", "111": "블록 필드값 수정", "117": "블록 쓰레드 추가하기", "118": "블록 끼워넣기", "119": "블록 이동하기", "120": "블록 분리하기", "121": "블록 이동하기", "122": "블록 끼워넣기", "123": "블록 끼워넣기", "201": "오브젝트 선택하기", "301": "do", "302": "undo", "303": "redo", "401": "그림 수정하기", "402": "그림 수정 취소하기", "403": "그림 수정하기", "404": "그림 수정 취소하기", "501": "시작하기", "502": "정지하기", "601": "컨테이너 오브젝트 선택하기", "701": "모드 바꾸기", "702": "모양 추가 버튼 클릭", "703": "소리 추가 버튼 클릭", "801": "변수 속성창 필터 선택하기", "802": "변수 추가하기 버튼 클릭", "803": "변수 추가하기", "804": "변수 삭제하기", "805": "변수 이름 설정" }; Lang.CommandTooltip = { "101": "블록 쓰레드 추가하기", "102": "블록 쓰레드 삭제하기", "103": "블록 삭제하기", "104": "블록 복구하기", "105": "코드 분리하기$$코드 연결하기@@이 코드의 가장 위에 있는 블록을 잡고 분리하여 끌어옵니다.$$이 곳에 코드를 연결합니다.$$이 곳에 블록의 왼쪽 끝을 끼워 넣습니다.", "106": "블록 분리하기", "107": "블록 이동하기", "108": "블록 복제하기", "109": "블록 복제 취소하기", "110": "스크롤", "111": "블록 필드값 수정@@값을 입력하기 위해 이곳을 클릭합니다.$$선택지를 클릭합니다.$$선택지를 클릭합니다.$$&value&을 입력합니다.$$&value&를 선택합니다.$$키보드 &value&를 누릅니다.", "117": "블록 쓰레드 추가하기", "118": "블록 연결하기@@이 곳에 블록을 연결합니다.$$이 곳에 블록의 왼쪽 끝을 끼워 넣습니다.", "119": "블록 가져오기@@빈 곳에 블록을 끌어다 놓습니다.", "120": "블록 분리하기$$블록 삭제하기@@필요 없는 코드를 <b>휴지통</b>으로 끌어옵니다.$$이 곳에 코드를 버립니다.", "121": "블록 이동하기$$블록 삭제하기@@필요 없는 코드를 <b>휴지통</b>으로 끌어옵니다.$$이 곳에 코드를 버립니다.", "122": "블록 연결하기@@이 곳에 블록을 연결합니다.$$이 곳에 블록의 왼쪽 끝을 끼워 넣습니다.", "123": "코드 분리하기$$코드 연결하기@@이 코드의 가장 위에 있는 블록을 잡고 분리하여 끌어옵니다.$$이 곳에 코드를 연결합니다.$$이 곳에 블록의 왼쪽 끝을 끼워 넣습니다.", "201": "오브젝트 선택하기", "301": "do", "302": "undo", "303": "redo", "401": "그림 수정하기", "402": "그림 수정 취소하기", "403": "그림 수정하기", "404": "그림 수정 취소하기", "501": "실행하기@@<b>[시작하기]</b>를 누릅니다.", "502": "정지하기@@<b>[정지하기]</b>를 누릅니다.", "601": "컨테이너 오브젝트 선택하기", "701": "모드 바꾸기", "702": "모양 추가하기@@<b>모양추가</b>를 클릭합니다.", "703": "소리 추가하기@@<b>소리추가</b>를 클릭합니다.", "801": "변수 속성창 필터 선택하기", "802": "변수 추가하기@@<b>[변수 추가]</b>를 클릭합니다.", "803": "변수 추가하기@@<b>[확인]</b>을 클릭합니다.", "804": "변수 삭제하기@@이 버튼을 눌러 변수를 삭제합니다.", "805": "변수 이름 설정" }; Lang.Blocks = { "download_guide": "연결 안내 다운로드", "ARDUINO": "하드웨어", "ARDUINO_download_connector": "연결 프로그램 다운로드", "ARDUINO_open_connector": "연결 프로그램 열기", "ARDUINO_download_source": "엔트리 아두이노 소스", "ARDUINO_reconnect": "하드웨어 연결하기", "ROBOT_reconnect": "로봇 연결하기", "ARDUINO_program": "프로그램 실행하기", "ARDUINO_cloud_pc_connector": "클라우드 PC 연결하기", "ARDUINO_connected": "하드웨어가 연결되었습니다. ", "ARDUINO_connect": "하드웨어를 연결하세요.", "ARDUINO_arduino_get_number_1": "신호", "ARDUINO_arduino_get_number_2": "의 숫자 결과값", "ARDUINO_arduino_get_sensor_number_0": "0", "ARDUINO_arduino_get_sensor_number_1": "1", "ARDUINO_arduino_get_sensor_number_2": "2", "ARDUINO_arduino_get_sensor_number_3": "3", "ARDUINO_arduino_get_sensor_number_4": "4", "ARDUINO_arduino_get_sensor_number_5": "5", "blacksmith_toggle_on": "켜기", "blacksmith_toggle_off": "끄기", "blacksmith_lcd_first_line": "첫 번째", "blacksmith_lcd_seconds_line": "두 번째", "BITBRICK_light": "밝기센서", "BITBRICK_IR": "거리센서", "BITBRICK_touch": "버튼", "BITBRICK_potentiometer": "가변저항", "BITBRICK_MIC": "소리감지센서", "BITBRICK_UserSensor": "사용자입력", "BITBRICK_UserInput": "사용자입력", "BITBRICK_dc_direction_ccw": "반시계", "BITBRICK_dc_direction_cw": "시계", "byrobot_dronefighter_drone_state_mode_system": "시스템 모드", "byrobot_dronefighter_drone_state_mode_vehicle": "드론파이터 모드", "byrobot_dronefighter_drone_state_mode_flight": "비행 모드", "byrobot_dronefighter_drone_state_mode_drive": "자동차 모드", "byrobot_dronefighter_drone_state_mode_coordinate": "기본 좌표계", "byrobot_dronefighter_drone_state_battery": "배터리", "byrobot_dronefighter_drone_attitude_roll": "자세 Roll", "byrobot_dronefighter_drone_attitude_pitch": "자세 Pitch", "byrobot_dronefighter_drone_attitude_yaw": "자세 Yaw", "byrobot_dronefighter_drone_irmessage": "적외선 수신 값", "byrobot_dronefighter_controller_joystick_left_x": "왼쪽 조이스틱 가로축", "byrobot_dronefighter_controller_joystick_left_y": "왼쪽 조이스틱 세로축", "byrobot_dronefighter_controller_joystick_left_direction": "왼쪽 조이스틱 방향", "byrobot_dronefighter_controller_joystick_left_event": "왼쪽 조이스틱 이벤트", "byrobot_dronefighter_controller_joystick_left_command": "왼쪽 조이스틱 명령", "byrobot_dronefighter_controller_joystick_right_x": "오른쪽 조이스틱 가로축", "byrobot_dronefighter_controller_joystick_right_y": "오른쪽 조이스틱 세로축", "byrobot_dronefighter_controller_joystick_right_direction": "오른쪽 조이스틱 방향", "byrobot_dronefighter_controller_joystick_right_event": "오른쪽 조이스틱 이벤트", "byrobot_dronefighter_controller_joystick_right_command": "오른쪽 조이스틱 명령", "byrobot_dronefighter_controller_joystick_direction_left_up": "왼쪽 위", "byrobot_dronefighter_controller_joystick_direction_up": "위", "byrobot_dronefighter_controller_joystick_direction_right_up": "오른쪽 위", "byrobot_dronefighter_controller_joystick_direction_left": "왼쪽", "byrobot_dronefighter_controller_joystick_direction_center": "중앙", "byrobot_dronefighter_controller_joystick_direction_right": "오른쪽", "byrobot_dronefighter_controller_joystick_direction_left_down": "왼쪽 아래", "byrobot_dronefighter_controller_joystick_direction_down": "아래", "byrobot_dronefighter_controller_joystick_direction_right_down": "오른쪽 아래", "byrobot_dronefighter_controller_button_button": "버튼", "byrobot_dronefighter_controller_button_event": "버튼 이벤트", "byrobot_dronefighter_controller_button_front_left": "왼쪽 빨간 버튼", "byrobot_dronefighter_controller_button_front_right": "오른쪽 빨간 버튼", "byrobot_dronefighter_controller_button_front_left_right": "양쪽 빨간 버튼", "byrobot_dronefighter_controller_button_center_up_left": "트림 좌회전 버튼", "byrobot_dronefighter_controller_button_center_up_right": "트림 우회전 버튼", "byrobot_dronefighter_controller_button_center_up": "트림 앞 버튼", "byrobot_dronefighter_controller_button_center_left": "트림 왼쪽 버튼", "byrobot_dronefighter_controller_button_center_right": "트림 오른쪽 버튼", "byrobot_dronefighter_controller_button_center_down": "트림 뒤 버튼", "byrobot_dronefighter_controller_button_bottom_left": "왼쪽 둥근 버튼", "byrobot_dronefighter_controller_button_bottom_right": "오른쪽 둥근 버튼", "byrobot_dronefighter_controller_button_bottom_left_right": "양쪽 둥근 버튼", "byrobot_dronefighter_entryhw_count_transfer_reserved": "전송 예약된 데이터 수", "byrobot_dronefighter_common_roll": "Roll", "byrobot_dronefighter_common_pitch": "Pitch", "byrobot_dronefighter_common_yaw": "Yaw", "byrobot_dronefighter_common_throttle": "Throttle", "byrobot_dronefighter_common_left": "왼쪽", "byrobot_dronefighter_common_right": "오른쪽", "byrobot_dronefighter_common_light_manual_on": "켜기", "byrobot_dronefighter_common_light_manual_off": "끄기", "byrobot_dronefighter_common_light_manual_b25": "밝기 25%", "byrobot_dronefighter_common_light_manual_b50": "밝기 50%", "byrobot_dronefighter_common_light_manual_b75": "밝기 75%", "byrobot_dronefighter_common_light_manual_b100": "밝기 100%", "byrobot_dronefighter_common_light_manual_all": "전체", "byrobot_dronefighter_common_light_manual_red": "빨강", "byrobot_dronefighter_common_light_manual_blue": "파랑", "byrobot_dronefighter_common_light_manual_1": "1", "byrobot_dronefighter_common_light_manual_2": "2", "byrobot_dronefighter_common_light_manual_3": "3", "byrobot_dronefighter_common_light_manual_4": "4", "byrobot_dronefighter_common_light_manual_5": "5", "byrobot_dronefighter_common_light_manual_6": "6", "byrobot_dronefighter_controller_buzzer": "버저", "byrobot_dronefighter_controller_buzzer_mute": "쉼", "byrobot_dronefighter_controller_buzzer_c": "도", "byrobot_dronefighter_controller_buzzer_cs": "도#", "byrobot_dronefighter_controller_buzzer_d": "레", "byrobot_dronefighter_controller_buzzer_ds": "레#", "byrobot_dronefighter_controller_buzzer_e": "미", "byrobot_dronefighter_controller_buzzer_f": "파", "byrobot_dronefighter_controller_buzzer_fs": "파#", "byrobot_dronefighter_controller_buzzer_g": "솔", "byrobot_dronefighter_controller_buzzer_gs": "솔#", "byrobot_dronefighter_controller_buzzer_a": "라", "byrobot_dronefighter_controller_buzzer_as": "라#", "byrobot_dronefighter_controller_buzzer_b": "시", "byrobot_dronefighter_controller_userinterface_preset_clear": "모두 지우기", "byrobot_dronefighter_controller_userinterface_preset_dronefighter2017": "기본", "byrobot_dronefighter_controller_userinterface_preset_education": "교육용", "byrobot_dronefighter_controller_userinterface_command_setup_button_frontleft_down": "왼쪽 빨간 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_frontright_down": "오른쪽 빨간 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_midturnleft_down": "트림 좌회전 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_midturnright_down": "트림 우회전 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_midup_down": "트림 앞 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_midleft_down": "트림 왼쪽 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_midright_down": "트림 오른쪽 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_button_middown_down": "트림 뒤 버튼을 눌렀을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_left_up_in": "왼쪽 조이스틱을 위로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_left_left_in": "왼쪽 조이스틱을 왼쪽으로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_left_right_in": "왼쪽 조이스틱을 오른쪽으로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_left_down_in": "왼쪽 조이스틱을 아래로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_right_up_in": "오른쪽 조이스틱을 위로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_right_left_in": "오른쪽 조이스틱을 왼쪽으로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_right_right_in": "오른쪽 조이스틱을 오른쪽으로 움직였을 때", "byrobot_dronefighter_controller_userinterface_command_setup_joystick_right_down_in": "오른쪽 조이스틱을 아래로 움직였을 때", "byrobot_dronefighter_controller_userinterface_function_joystickcalibration_reset": "조이스틱 보정 초기화", "byrobot_dronefighter_controller_userinterface_function_change_team_red": "팀 - 레드", "byrobot_dronefighter_controller_userinterface_function_change_team_blue": "팀 - 블루", "byrobot_dronefighter_controller_userinterface_function_change_mode_vehicle_flight": "드론", "byrobot_dronefighter_controller_userinterface_function_change_mode_vehicle_flightnoguard": "드론 - 가드 없음", "byrobot_dronefighter_controller_userinterface_function_change_mode_vehicle_drive": "자동차", "byrobot_dronefighter_controller_userinterface_function_change_coordinate_local": "방위 - 일반", "byrobot_dronefighter_controller_userinterface_function_change_coordinate_world": "방위 - 앱솔루트", "byrobot_dronefighter_controller_userinterface_function_change_mode_control_mode1": "조종 - MODE 1", "byrobot_dronefighter_controller_userinterface_function_change_mode_control_mode2": "조종 - MODE 2", "byrobot_dronefighter_controller_userinterface_function_change_mode_control_mode3": "조종 - MODE 3", "byrobot_dronefighter_controller_userinterface_function_change_mode_control_mode4": "조종 - MODE 4", "byrobot_dronefighter_controller_userinterface_function_gyrobias_reset": "자이로 바이어스 리셋", "byrobot_dronefighter_controller_userinterface_function_change_mode_usb_cdc": "USB 시리얼 통신 장치", "byrobot_dronefighter_controller_userinterface_function_change_mode_usb_hid": "USB 게임 컨트롤러", "byrobot_dronefighter_drone_team": "팀 ", "byrobot_dronefighter_drone_team_red": "레드", "byrobot_dronefighter_drone_team_blue": "블루", "byrobot_dronefighter_drone_coordinate_world": "앱솔루트", "byrobot_dronefighter_drone_coordinate_local": "일반", "byrobot_dronefighter_drone_mode_vehicle_flight": "드론", "byrobot_dronefighter_drone_mode_vehicle_drive": "자동차", "byrobot_dronefighter_drone_control_double_wheel": "방향", "byrobot_dronefighter_drone_control_double_wheel_left": "왼쪽 회전", "byrobot_dronefighter_drone_control_double_wheel_right": "오른쪽 회전", "byrobot_dronefighter_drone_control_double_accel_forward": "전진", "byrobot_dronefighter_drone_control_double_accel_backward": "후진", "byrobot_dronefighter_drone_control_quad_roll": "Roll", "byrobot_dronefighter_drone_control_quad_pitch": "Pitch", "byrobot_dronefighter_drone_control_quad_yaw": "Yaw", "byrobot_dronefighter_drone_control_quad_throttle": "Throttle", "byrobot_dronefighter_drone_control_quad_roll_left": "왼쪽", "byrobot_dronefighter_drone_control_quad_roll_right": "오른쪽", "byrobot_dronefighter_drone_control_quad_pitch_forward": "앞으로", "byrobot_dronefighter_drone_control_quad_pitch_backward": "뒤로", "byrobot_dronefighter_drone_control_quad_yaw_left": "왼쪽 회전", "byrobot_dronefighter_drone_control_quad_yaw_right": "오른쪽 회전", "byrobot_dronefighter_drone_control_quad_throttle_up": "위", "byrobot_dronefighter_drone_control_quad_throttle_down": "아래", "byrobot_petrone_v2_common_left": "왼쪽", "byrobot_petrone_v2_common_light_color_cottoncandy": "구름솜사탕", "byrobot_petrone_v2_common_light_color_emerald": "에메랄드", "byrobot_petrone_v2_common_light_color_lavender": "라벤더", "byrobot_petrone_v2_common_light_mode_dimming": "천천히 깜빡임", "byrobot_petrone_v2_common_light_mode_flicker": "깜빡임", "byrobot_petrone_v2_common_light_mode_flicker_double": "2번 연속 깜빡임", "byrobot_petrone_v2_common_light_mode_hold": "켜짐", "byrobot_petrone_v2_common_light_color_muscat": "청포도", "byrobot_petrone_v2_common_light_color_strawberrymilk": "딸기우유", "byrobot_petrone_v2_common_light_color_sunset": "저녁노을", "byrobot_petrone_v2_common_light_manual_all": "전체", "byrobot_petrone_v2_common_light_manual_b100": "밝기 100%", "byrobot_petrone_v2_common_light_manual_b25": "밝기 25%", "byrobot_petrone_v2_common_light_manual_b50": "밝기 50%", "byrobot_petrone_v2_common_light_manual_b75": "밝기 75%", "byrobot_petrone_v2_common_light_manual_blue": "파랑", "byrobot_petrone_v2_common_light_manual_cyan": "하늘색", "byrobot_petrone_v2_common_light_manual_green": "초록", "byrobot_petrone_v2_common_light_manual_magenta": "핑크", "byrobot_petrone_v2_common_light_manual_off": "끄기", "byrobot_petrone_v2_common_light_manual_on": "켜기", "byrobot_petrone_v2_common_light_manual_red": "빨강", "byrobot_petrone_v2_common_light_manual_white": "흰색", "byrobot_petrone_v2_common_light_manual_yellow": "노랑", "byrobot_petrone_v2_common_pitch": "Pitch", "byrobot_petrone_v2_common_right": "오른쪽", "byrobot_petrone_v2_common_roll": "Roll", "byrobot_petrone_v2_common_throttle": "Throttle", "byrobot_petrone_v2_common_yaw": "Yaw", "byrobot_petrone_v2_controller_button_bottom_left": "왼쪽 둥근 버튼", "byrobot_petrone_v2_controller_button_bottom_left_right": "양쪽 둥근 버튼", "byrobot_petrone_v2_controller_button_bottom_right": "오른쪽 둥근 버튼", "byrobot_petrone_v2_controller_button_button": "버튼", "byrobot_petrone_v2_controller_button_center_down": "트림 뒤 버튼", "byrobot_petrone_v2_controller_button_center_left": "트림 왼쪽 버튼", "byrobot_petrone_v2_controller_button_center_right": "트림 오른쪽 버튼", "byrobot_petrone_v2_controller_button_center_up": "트림 앞 버튼", "byrobot_petrone_v2_controller_button_center_up_left": "트림 좌회전 버튼", "byrobot_petrone_v2_controller_button_center_up_right": "트림 우회전 버튼", "byrobot_petrone_v2_controller_button_event": "버튼 이벤트", "byrobot_petrone_v2_controller_button_front_left": "왼쪽 빨간 버튼", "byrobot_petrone_v2_controller_button_front_left_right": "양쪽 빨간 버튼", "byrobot_petrone_v2_controller_button_front_right": "오른쪽 빨간 버튼", "byrobot_petrone_v2_controller_buzzer": "버저", "byrobot_petrone_v2_controller_buzzer_a": "라", "byrobot_petrone_v2_controller_buzzer_as": "라#", "byrobot_petrone_v2_controller_buzzer_b": "시", "byrobot_petrone_v2_controller_buzzer_c": "도", "byrobot_petrone_v2_controller_buzzer_cs": "도#", "byrobot_petrone_v2_controller_buzzer_d": "레", "byrobot_petrone_v2_controller_buzzer_ds": "레#", "byrobot_petrone_v2_controller_buzzer_e": "미", "byrobot_petrone_v2_controller_buzzer_f": "파", "byrobot_petrone_v2_controller_buzzer_fs": "파#", "byrobot_petrone_v2_controller_buzzer_g": "솔", "byrobot_petrone_v2_controller_buzzer_gs": "솔#", "byrobot_petrone_v2_controller_buzzer_mute": "쉼", "byrobot_petrone_v2_controller_display_align_center": "가운데", "byrobot_petrone_v2_controller_display_align_left": "왼쪽", "byrobot_petrone_v2_controller_display_align_right": "오른쪽", "byrobot_petrone_v2_controller_display_flagfill_off": "채우지 않음", "byrobot_petrone_v2_controller_display_flagfill_on": "채움", "byrobot_petrone_v2_controller_display_font_10x16": "큼", "byrobot_petrone_v2_controller_display_font_5x8": "작음", "byrobot_petrone_v2_controller_display_line_dashed": "파선", "byrobot_petrone_v2_controller_display_line_dotted": "점선", "byrobot_petrone_v2_controller_display_line_solid": "실선", "byrobot_petrone_v2_controller_display_pixel_black": "검은색", "byrobot_petrone_v2_controller_display_pixel_white": "흰색", "byrobot_petrone_v2_controller_joystick_direction_center": "중앙", "byrobot_petrone_v2_controller_joystick_direction_down": "아래", "byrobot_petrone_v2_controller_joystick_direction_left": "왼쪽", "byrobot_petrone_v2_controller_joystick_direction_left_down": "왼쪽 아래", "byrobot_petrone_v2_controller_joystick_direction_left_up": "왼쪽 위", "byrobot_petrone_v2_controller_joystick_direction_right": "오른쪽", "byrobot_petrone_v2_controller_joystick_direction_right_down": "오른쪽 아래", "byrobot_petrone_v2_controller_joystick_direction_right_up": "오른쪽 위", "byrobot_petrone_v2_controller_joystick_direction_up": "위", "byrobot_petrone_v2_controller_joystick_left_direction": "왼쪽 조이스틱 방향", "byrobot_petrone_v2_controller_joystick_left_event": "왼쪽 조이스틱 이벤트", "byrobot_petrone_v2_controller_joystick_left_x": "왼쪽 조이스틱 가로축", "byrobot_petrone_v2_controller_joystick_left_y": "왼쪽 조이스틱 세로축", "byrobot_petrone_v2_controller_joystick_right_direction": "오른쪽 조이스틱 방향", "byrobot_petrone_v2_controller_joystick_right_event": "오른쪽 조이스틱 이벤트", "byrobot_petrone_v2_controller_joystick_right_x": "오른쪽 조이스틱 가로축", "byrobot_petrone_v2_controller_joystick_right_y": "오른쪽 조이스틱 세로축", "byrobot_petrone_v2_drone_accel_x": "가속도 x", "byrobot_petrone_v2_drone_accel_y": "가속도 y", "byrobot_petrone_v2_drone_accel_z": "가속도 z", "byrobot_petrone_v2_drone_attitude_pitch": "자세 Pitch", "byrobot_petrone_v2_drone_attitude_roll": "자세 Roll", "byrobot_petrone_v2_drone_attitude_yaw": "자세 Yaw", "byrobot_petrone_v2_drone_control_double_accel_forward": "전진/후진", "byrobot_petrone_v2_drone_control_double_wheel": "방향", "byrobot_petrone_v2_drone_control_double_wheel_left": "왼쪽 회전", "byrobot_petrone_v2_drone_control_double_wheel_right": "오른쪽 회전", "byrobot_petrone_v2_drone_control_quad_pitch": "Pitch", "byrobot_petrone_v2_drone_control_quad_pitch_backward": "뒤로", "byrobot_petrone_v2_drone_control_quad_pitch_forward": "앞으로", "byrobot_petrone_v2_drone_control_quad_roll": "Roll", "byrobot_petrone_v2_drone_control_quad_roll_left": "왼쪽", "byrobot_petrone_v2_drone_control_quad_roll_right": "오른쪽", "byrobot_petrone_v2_drone_control_quad_throttle": "Throttle", "byrobot_petrone_v2_drone_control_quad_throttle_down": "아래", "byrobot_petrone_v2_drone_control_quad_throttle_up": "위", "byrobot_petrone_v2_drone_control_quad_yaw": "Yaw", "byrobot_petrone_v2_drone_control_quad_yaw_left": "왼쪽 회전", "byrobot_petrone_v2_drone_control_quad_yaw_right": "오른쪽 회전", "byrobot_petrone_v2_drone_coordinate_local": "off (숙련자용)", "byrobot_petrone_v2_drone_coordinate_world": "on (초보자용)", "byrobot_petrone_v2_drone_gyro_pitch": "각속도 Pitch", "byrobot_petrone_v2_drone_gyro_roll": "각속도 Roll", "byrobot_petrone_v2_drone_gyro_yaw": "각속도 Yaw", "byrobot_petrone_v2_drone_imageflow_positionX": "image flow X", "byrobot_petrone_v2_drone_imageflow_positionY": "image flow Y", "byrobot_petrone_v2_drone_irmessage": "적외선 수신 값", "byrobot_petrone_v2_drone_irmessage_direction": "적외선 수신 방향", "byrobot_petrone_v2_drone_irmessage_direction_front": "앞", "byrobot_petrone_v2_drone_irmessage_direction_rear": "뒤", "byrobot_petrone_v2_drone_light_color_arm": "팔", "byrobot_petrone_v2_drone_light_color_eye": "눈", "byrobot_petrone_v2_drone_light_manual_arm_blue": "팔 파랑", "byrobot_petrone_v2_drone_light_manual_arm_green": "팔 초록", "byrobot_petrone_v2_drone_light_manual_arm_red": "팔 빨강", "byrobot_petrone_v2_drone_light_manual_eye_blue": "눈 파랑", "byrobot_petrone_v2_drone_light_manual_eye_green": "눈 초록", "byrobot_petrone_v2_drone_light_manual_eye_red": "눈 빨강", "byrobot_petrone_v2_drone_motor_rotation_clockwise": "시계 방향", "byrobot_petrone_v2_drone_motor_rotation_counterclockwise": "반시계 방향", "byrobot_petrone_v2_drone_pressure_pressure": "해발고도", "byrobot_petrone_v2_drone_pressure_temperature": "온도", "byrobot_petrone_v2_drone_range_bottom": "바닥까지 거리", "byrobot_petrone_v2_drone_state_battery": "배터리", "byrobot_petrone_v2_drone_state_mode_coordinate": "기본 좌표계", "byrobot_petrone_v2_drone_state_mode_drive": "자동차 동작 상태", "byrobot_petrone_v2_drone_state_mode_flight": "비행 동작 상태", "byrobot_petrone_v2_drone_state_mode_system": "시스템 모드", "byrobot_petrone_v2_drone_state_mode_vehicle": "Vehicle mode", "byrobot_petrone_v2_drone_team": "팀 ", "byrobot_petrone_v2_drone_team_blue": "블루", "byrobot_petrone_v2_drone_team_red": "레드", "byrobot_petrone_v2_drone_vehicle_drive": "자동차", "byrobot_petrone_v2_drone_vehicle_drive_fpv": "자동차(FPV)", "byrobot_petrone_v2_drone_vehicle_flight": "드론(가드 포함)", "byrobot_petrone_v2_drone_vehicle_flight_fpv": "드론(FPV)", "byrobot_petrone_v2_drone_vehicle_flight_noguard": "드론(가드 없음)", "byrobot_petrone_v2_entryhw_count_transfer_reserved": "전송 예약된 데이터 수", "chocopi_control_event_pressed": "누를 때", "chocopi_control_event_released": "뗄 때", "chocopi_joystick_X": "조이스틱 좌우", "chocopi_joystick_Y": "조이스틱 상하", "chocopi_motion_photogate_event_blocked": "막았을 때", "chocopi_motion_photogate_event_unblocked": "열었을 때", "chocopi_motion_photogate_time_blocked": "막은 시간", "chocopi_motion_photogate_time_unblocked": "연 시간", "chocopi_port": "포트", "chocopi_pot": "볼륨", "chocopi_touch_event_touch": "만질 때", "chocopi_touch_event_untouch": "뗄 때", "CODEino_get_sensor_number_0": "0", "CODEino_get_sensor_number_1": "1", "CODEino_get_sensor_number_2": "2", "CODEino_get_sensor_number_3": "3", "CODEino_get_sensor_number_4": "4", "CODEino_get_sensor_number_5": "5", "CODEino_get_sensor_number_6": "6", "CODEino_sensor_name_0": "소리", "CODEino_sensor_name_1": "빛", "CODEino_sensor_name_2": "슬라이더", "CODEino_sensor_name_3": "저항-A", "CODEino_sensor_name_4": "저항-B", "CODEino_sensor_name_5": "저항-C", "CODEino_sensor_name_6": "저항-D", "CODEino_string_1": " 센서값 ", "CODEino_string_2": " 보드의 ", "CODEino_string_3": "버튼누름", "CODEino_string_4": "A 연결됨", "CODEino_string_5": "B 연결됨", "CODEino_string_6": "C 연결됨", "CODEino_string_7": "D 연결됨", "CODEino_string_8": " 3축 가속도센서 ", "CODEino_string_9": "축의 센서값 ", "CODEino_string_10": "소리센서 ", "CODEino_string_11": "소리큼", "CODEino_string_12": "소리작음", "CODEino_string_13": "빛센서 ", "CODEino_string_14": "밝음", "CODEino_string_15": "어두움", "CODEino_string_16": "왼쪽 기울임", "CODEino_string_17": "오른쪽 기울임", "CODEino_string_18": "위쪽 기울임", "CODEino_string_19": "아래쪽 기울임", "CODEino_string_20": "뒤집힘", "CODEino_accelerometer_X": "X", "CODEino_accelerometer_Y": "Y", "CODEino_accelerometer_Z": "Z", "CODEino_led_red": "빨강", "CODEino_led_green": "초록", "CODEino_led_blue": "파랑", "iboard_analog_number_0": "A0", "iboard_analog_number_1": "A1", "iboard_analog_number_2": "A2", "iboard_analog_number_3": "A3", "iboard_analog_number_4": "A4", "iboard_analog_number_5": "A5", "iboard_light": "빛센서가 ", "iboard_num_pin_1": "LED 상태를", "iboard_num_pin_2": "번 스위치가", "iboard_num_pin_3": "아날로그", "iboard_num_pin_4": "번 ", "iboard_num_pin_5": "센서값", "iboard_string_1": "켜짐", "iboard_string_2": "꺼짐", "iboard_string_3": "밝음", "iboard_string_4": "어두움", "iboard_string_5": "눌림", "iboard_string_6": "열림", "iboard_switch": "스위치 ", "iboard_tilt": "기울기센서 상태가", "dplay_switch": "스위치 ", "dplay_light": "빛센서가 ", "dplay_tilt": "기울기센서 상태가", "dplay_string_1": "켜짐", "dplay_string_2": "꺼짐", "dplay_string_3": "밝음", "dplay_string_4": "어두움", "dplay_string_5": "눌림", "dplay_string_6": "열림", "dplay_num_pin_1": "LED 상태를", "dplay_num_pin_2": "번 스위치가", "dplay_num_pin_3": "아날로그", "dplay_num_pin_4": "번 ", "dplay_num_pin_5": "센서값", "dplay_analog_number_0": "A0", "dplay_analog_number_1": "A1", "dplay_analog_number_2": "A2", "dplay_analog_number_3": "A3", "dplay_analog_number_4": "A4", "dplay_analog_number_5": "A5", "ARDUINO_arduino_get_string_1": "신호", "ARDUINO_arduino_get_string_2": "의 글자 결과값", "ARDUINO_arduino_send_1": "신호", "ARDUINO_arduino_send_2": "보내기", "ARDUINO_num_sensor_value_1": "아날로그", "ARDUINO_num_sensor_value_2": "번 센서값", "ARDUINO_get_digital_value_1": "디지털", "ARDUINO_num_pin_1": "디지털", "ARDUINO_num_pin_2": "번 핀", "ARDUINO_toggle_pwm_1": "디지털", "ARDUINO_toggle_pwm_2": "번 핀을", "ARDUINO_toggle_pwm_3": "(으)로 정하기", "ARDUINO_on": "켜기", "ARDUINO_convert_scale_1": "", "ARDUINO_convert_scale_2": "값의 범위를", "ARDUINO_convert_scale_3": "~", "ARDUINO_convert_scale_4": "에서", "ARDUINO_convert_scale_5": "~", "ARDUINO_convert_scale_6": "(으)로 바꾼값", "ARDUINO_off": "끄기", "brightness": "밝기", "BRUSH": "붓", "BRUSH_brush_erase_all": "모든 붓 지우기", "BRUSH_change_opacity_1": "붓의 불투명도를", "BRUSH_change_opacity_2": "% 만큼 바꾸기", "BRUSH_change_thickness_1": "붓의 굵기를", "BRUSH_change_thickness_2": "만큼 바꾸기", "BRUSH_set_color_1": "붓의 색을", "BRUSH_set_color_2": "(으)로 정하기", "BRUSH_set_opacity_1": "붓의 불투명도를", "BRUSH_set_opacity_2": "% 로 정하기", "BRUSH_set_random_color": "붓의 색을 무작위로 정하기", "BRUSH_set_thickness_1": "붓의 굵기를", "BRUSH_set_thickness_2": "(으)로 정하기", "BRUSH_stamp": "도장찍기", "BRUSH_start_drawing": "그리기 시작하기", "BRUSH_stop_drawing": "그리기 멈추기", "CALC": "계산", "CALC_calc_mod_1": "", "CALC_calc_mod_2": "/", "CALC_calc_mod_3": "의 나머지", "CALC_calc_operation_of_1": "", "CALC_calc_operation_of_2": "의", "CALC_calc_operation_root": "루트", "CALC_calc_operation_square": "제곱", "CALC_calc_rand_1": "", "CALC_calc_rand_2": "부터", "CALC_calc_rand_3": "사이의 무작위 수", "CALC_calc_share_1": "", "CALC_calc_share_2": "/", "CALC_calc_share_3": "의 몫", "CALC_coordinate_mouse_1": "마우스", "CALC_coordinate_mouse_2": "좌표", "CALC_coordinate_object_1": "", "CALC_coordinate_object_2": "의", "CALC_coordinate_object_3": "", "CALC_distance_something_1": "", "CALC_distance_something_2": "까지의 거리", "CALC_get_angle": "각도값", "CALC_get_date_1": " 현재", "CALC_get_date_2": "", "CALC_get_date_day": "일", "CALC_get_date_hour": "시각(시)", "CALC_get_date_minute": "시각(분)", "CALC_get_date_month": "월", "CALC_get_date_second": "시각(초)", "CALC_get_date_year": "연도", "CALC_get_sound_duration_1": "", "CALC_get_sound_duration_2": "소리의 길이", "CALC_get_timer_value": " 초시계 값", "CALC_get_x_coordinate": "X 좌푯값", "CALC_get_y_coordinate": "Y 좌푯값", "CALC_timer_reset": "초시계 초기화", "CALC_timer_visible_1": "초시계", "CALC_timer_visible_2": "", "CALC_timer_visible_show": "보이기", "CALC_timer_visible_hide": "숨기기", "color": "색깔", "FLOW": "흐름", "FLOW__if_1": "만일", "FLOW__if_2": "이라면", "FLOW_create_clone_1": "", "FLOW_create_clone_2": "의 복제본 만들기", "FLOW_delete_clone": "이 복제본 삭제하기", "FLOW_delete_clone_all": "모든 복제본 삭제하기", "FLOW_if_else_1": "만일", "FLOW_if_else_2": "이라면", "FLOW_if_else_3": "아니면", "FLOW_repeat_basic_1": "", "FLOW_repeat_basic_2": "번 반복하기", "FLOW_repeat_basic_errorMsg": "반복 횟수는 0보다 같거나 커야 합니다.", "FLOW_repeat_inf": "계속 반복하기", "FLOW_restart": "처음부터 다시 실행하기", "FLOW_stop_object_1": "", "FLOW_stop_object_2": "멈추기", "FLOW_stop_object_all": "모든", "FLOW_stop_object_this_object": "자신의", "FLOW_stop_object_this_thread": "이", "FLOW_stop_object_other_thread": "자신의 다른", "FLOW_stop_object_other_objects": "다른 오브젝트의", "FLOW_stop_repeat": "반복 중단하기", "FLOW_stop_run": "프로그램 끝내기", "FLOW_wait_second_1": "", "FLOW_wait_second_2": "초 기다리기", "FLOW_wait_until_true_1": "", "FLOW_wait_until_true_2": "이(가) 될 때까지 기다리기", "FLOW_when_clone_start": "복제본이 처음 생성되었을때", "FUNC": "함수", "JUDGEMENT": "판단", "JUDGEMENT_boolean_and": "그리고", "JUDGEMENT_boolean_not_1": "", "JUDGEMENT_boolean_not_2": "(이)가 아니다", "JUDGEMENT_boolean_or": "또는", "JUDGEMENT_false": " 거짓 ", "JUDGEMENT_is_clicked": "마우스를 클릭했는가?", "JUDGEMENT_is_press_some_key_1": "", "JUDGEMENT_is_press_some_key_2": "키가 눌러져 있는가?", "JUDGEMENT_reach_something_1": "", "JUDGEMENT_reach_something_2": "에 닿았는가?", "JUDGEMENT_true": " 참 ", "LOOKS": "생김새", "LOOKS_change_scale_percent_1": "크기를", "LOOKS_change_scale_percent_2": "만큼 바꾸기", "LOOKS_change_to_next_shape": "다음 모양으로 바꾸기", "LOOKS_change_to_nth_shape_1": "", "LOOKS_change_to_nth_shape_2": "모양으로 바꾸기", "LOOKS_change_shape_prev": "이전", "LOOKS_change_shape_next": "다음", "LOOKS_change_to_near_shape_1": "", "LOOKS_change_to_near_shape_2": "모양으로 바꾸기", "LOOKS_dialog_1": "", "LOOKS_dialog_2": "을(를)", "LOOKS_dialog_3": "", "LOOKS_dialog_time_1": "", "LOOKS_dialog_time_2": "을(를)", "LOOKS_dialog_time_3": "초 동안", "LOOKS_dialog_time_4": "", "LOOKS_erase_all_effects": "효과 모두 지우기", "LOOKS_flip_x": "상하 모양 뒤집기", "LOOKS_flip_y": "좌우 모양 뒤집기", "LOOKS_hide": "모양 숨기기", "LOOKS_remove_dialog": "말하기 지우기", "LOOKS_set_effect_1": "", "LOOKS_set_effect_2": "효과를", "LOOKS_set_effect_3": "(으)로 정하기", "LOOKS_set_effect_volume_1": "", "LOOKS_set_effect_volume_2": "효과를", "LOOKS_set_effect_volume_3": "만큼 주기", "LOOKS_set_object_order_1": "", "LOOKS_set_object_order_2": "번째로 올라오기", "LOOKS_set_scale_percent_1": "크기를", "LOOKS_set_scale_percent_2": " (으)로 정하기", "LOOKS_show": "모양 보이기", "mouse_pointer": "마우스포인터", "MOVING": "움직임", "MOVING_bounce_wall": "화면 끝에 닿으면 튕기기", "MOVING_bounce_when_1": "", "MOVING_bounce_when_2": "에 닿으면 튕기기", "MOVING_flip_arrow_horizontal": "화살표 방향 좌우 뒤집기", "MOVING_flip_arrow_vertical": "화살표 방향 상하 뒤집기", "MOVING_locate_1": "", "MOVING_locate_2": "위치로 이동하기", "MOVING_locate_time_1": "", "MOVING_locate_time_2": "초 동안", "MOVING_locate_time_3": "위치로 이동하기", "MOVING_locate_x_1": "x:", "MOVING_locate_x_2": "위치로 이동하기", "MOVING_locate_xy_1": "x:", "MOVING_locate_xy_2": "y:", "MOVING_locate_xy_3": "위치로 이동하기", "MOVING_locate_xy_time_1": "", "MOVING_locate_xy_time_2": "초 동안 x:", "MOVING_locate_xy_time_3": "y:", "MOVING_locate_xy_time_4": "위치로 이동하기", "MOVING_locate_y_1": "y:", "MOVING_locate_y_2": "위치로 이동하기", "MOVING_move_direction_1": "이동 방향으로", "MOVING_move_direction_2": "만큼 움직이기", "MOVING_move_direction_angle_1": "", "MOVING_move_direction_angle_2": "방향으로", "MOVING_move_direction_angle_3": "만큼 움직이기", "MOVING_move_x_1": "x 좌표를", "MOVING_move_x_2": "만큼 바꾸기", "MOVING_move_xy_time_1": "", "MOVING_move_xy_time_2": "초 동안 x:", "MOVING_move_xy_time_3": "y:", "MOVING_move_xy_time_4": "만큼 움직이기", "MOVING_move_y_1": "y 좌표를", "MOVING_move_y_2": "만큼 바꾸기", "MOVING_rotate_by_angle_1": "오브젝트를", "MOVING_rotate_by_angle_2": "만큼 회전하기", "MOVING_rotate_by_angle_dropdown_1": "", "MOVING_rotate_by_angle_dropdown_2": "만큼 회전하기", "MOVING_rotate_by_angle_time_1": "오브젝트를", "MOVING_rotate_by_angle_time_2": "초 동안", "MOVING_rotate_by_angle_time_3": "만큼 회전하기", "MOVING_rotate_direction_1": "이동 방향을", "MOVING_rotate_direction_2": "만큼 회전하기", "MOVING_see_angle_1": "이동 방향을", "MOVING_see_angle_2": "(으)로 정하기", "MOVING_see_angle_direction_1": "오브젝트를", "MOVING_see_angle_direction_2": "(으)로 정하기", "MOVING_see_angle_object_1": "", "MOVING_see_angle_object_2": "쪽 바라보기", "MOVING_see_direction_1": "", "MOVING_see_direction_2": "쪽 보기", "MOVING_set_direction_by_angle_1": "방향을", "MOVING_set_direction_by_angle_2": "(으)로 정하기", "MOVING_add_direction_by_angle_1": "방향을", "MOVING_add_direction_by_angle_2": "만큼 회전하기", "MOVING_add_direction_by_angle_time_1": "방향을", "MOVING_add_direction_by_angle_time_2": "초 동안", "MOVING_add_direction_by_angle_time_3": "만큼 회전하기", "no_target": "대상없음", "oneself": "자신", "opacity": "불투명도", "SCENE": "장면", "SOUND": "소리", "SOUND_sound_silent_all": "모든 소리 멈추기", "SOUND_sound_something_1": "소리", "SOUND_sound_something_2": "재생하기", "SOUND_sound_something_second_1": "소리", "SOUND_sound_something_second_2": "", "SOUND_sound_something_second_3": "초 재생하기", "SOUND_sound_something_second_wait_1": "소리", "SOUND_sound_something_second_wait_2": "", "SOUND_sound_something_second_wait_3": "초 재생하고 기다리기", "SOUND_sound_something_wait_1": "소리 ", "SOUND_sound_something_wait_2": "재생하고 기다리기", "SOUND_sound_volume_change_1": "소리 크기를", "SOUND_sound_volume_change_2": "% 만큼 바꾸기", "SOUND_sound_volume_set_1": "소리 크기를", "SOUND_sound_volume_set_2": "% 로 정하기", "speak": "말하기", "START": "시작", "START_add_message": "신호 추가하기", "START_delete_message": "신호 삭제하기", "START_message_cast": "신호 보내기", "START_message_cast_1": "", "START_message_cast_2": "신호 보내기", "START_message_cast_wait": "신호 보내고 기다리기", "START_message_send_wait_1": "", "START_message_send_wait_2": "신호 보내고 기다리기", "START_mouse_click_cancled": "마우스 클릭을 해제했을 때", "START_mouse_clicked": "마우스를 클릭했을 때", "START_press_some_key_1": "", "START_press_some_key_2": "키를 눌렀을 때", "START_press_some_key_down": "아래쪽 화살표", "START_press_some_key_enter": "엔터", "START_press_some_key_left": "왼쪽 화살표", "START_press_some_key_right": "오른쪽 화살표", "START_press_some_key_space": "스페이스", "START_press_some_key_up": "위쪽 화살표", "START_when_message_cast": "신호를 받았을 때", "START_when_message_cast_1": "", "START_when_message_cast_2": "신호를 받았을 때", "START_when_object_click": "오브젝트를 클릭했을 때", "START_when_object_click_canceled": "오브젝트 클릭을 해제했을 때", "START_when_run_button_click": "시작하기 버튼을 클릭했을 때", "START_when_scene_start": "장면이 시작했을때", "START_when_some_key_click": "키를 눌렀을 때", "TEXT": "글상자", "TEXT_text": "엔트리", "TEXT_text_append_1": "", "TEXT_text_append_2": "라고 뒤에 이어쓰기", "TEXT_text_flush": "텍스트 모두 지우기", "TEXT_text_prepend_1": "", "TEXT_text_prepend_2": "라고 앞에 추가하기", "TEXT_text_write_1": "", "TEXT_text_write_2": "라고 글쓰기", "VARIABLE": "자료", "VARIABLE_add_value_to_list": "항목을 리스트에 추가하기", "VARIABLE_add_value_to_list_1": "", "VARIABLE_add_value_to_list_2": "항목을", "VARIABLE_add_value_to_list_3": "에 추가하기", "VARIABLE_ask_and_wait_1": "", "VARIABLE_ask_and_wait_2": "을(를) 묻고 대답 기다리기", "VARIABLE_change_value_list_index": "항목을 바꾸기", "VARIABLE_change_value_list_index_1": "", "VARIABLE_change_value_list_index_3": "번째 항목을", "VARIABLE_change_value_list_index_2": " ", "VARIABLE_change_value_list_index_4": "(으)로 바꾸기", "VARIABLE_change_variable": "변수 더하기", "VARIABLE_change_variable_1": "", "VARIABLE_change_variable_2": "에", "VARIABLE_change_variable_3": "만큼 더하기", "VARIABLE_change_variable_name": "변수 이름 바꾸기", "VARIABLE_combine_something_1": "", "VARIABLE_combine_something_2": "과(와)", "VARIABLE_combine_something_3": "를 합치기", "VARIABLE_get_canvas_input_value": " 대답 ", "VARIABLE_get_variable": "변수", "VARIABLE_get_variable_1": "값", "VARIABLE_get_variable_2": "값", "VARIABLE_get_y": "Y 좌푯값", "VARIABLE_hide_list": "리스트 숨기기", "VARIABLE_hide_list_1": "리스트", "VARIABLE_hide_list_2": "숨기기", "VARIABLE_hide_variable": "변수값 숨기기", "VARIABLE_hide_variable_1": "변수", "VARIABLE_hide_variable_2": "숨기기", "VARIABLE_insert_value_to_list": "항목을 넣기", "VARIABLE_insert_value_to_list_1": "", "VARIABLE_insert_value_to_list_2": "을(를)", "VARIABLE_insert_value_to_list_3": "의", "VARIABLE_insert_value_to_list_4": "번째에 넣기", "VARIABLE_length_of_list": "리스트의 길이", "VARIABLE_length_of_list_1": "", "VARIABLE_length_of_list_2": " 항목 수", "VARIABLE_list": "리스트", "VARIABLE_make_variable": "변수 만들기", "VARIABLE_list_option_first": "첫번째", "VARIABLE_list_option_last": "마지막", "VARIABLE_list_option_random": "무작위", "VARIABLE_remove_value_from_list": "항목을 삭제하기", "VARIABLE_remove_value_from_list_1": "", "VARIABLE_remove_value_from_list_2": "번째 항목을", "VARIABLE_remove_value_from_list_3": "에서 삭제하기", "VARIABLE_remove_variable": "변수 삭제", "VARIABLE_set_variable": "변수 정하기", "VARIABLE_set_variable_1": "", "VARIABLE_set_variable_2": "를", "VARIABLE_set_variable_3": "로 정하기", "VARIABLE_show_list": "리스트 보이기", "VARIABLE_show_list_1": "리스트", "VARIABLE_show_list_2": "보이기", "VARIABLE_show_variable": "변수값 보이기", "VARIABLE_show_variable_1": "변수", "VARIABLE_show_variable_2": "보이기", "VARIABLE_value_of_index_from_list": "리스트 항목의 값", "VARIABLE_value_of_index_from_list_1": "", "VARIABLE_value_of_index_from_list_2": "의", "VARIABLE_value_of_index_from_list_3": "번째 항목", "HAMSTER_hand_found": "손 찾음?", "HAMSTER_sensor_left_proximity": "왼쪽 근접 센서", "HAMSTER_sensor_right_proximity": "오른쪽 근접 센서", "HAMSTER_sensor_left_floor": "왼쪽 바닥 센서", "HAMSTER_sensor_right_floor": "오른쪽 바닥 센서", "HAMSTER_sensor_acceleration_x": "x축 가속도", "HAMSTER_sensor_acceleration_y": "y축 가속도", "HAMSTER_sensor_acceleration_z": "z축 가속도", "HAMSTER_sensor_light": "밝기", "HAMSTER_sensor_temperature": "온도", "HAMSTER_sensor_signal_strength": "신호 세기", "HAMSTER_sensor_input_a": "입력 A", "HAMSTER_sensor_input_b": "입력 B", "HAMSTER_move_forward_once": "말판 앞으로 한 칸 이동하기", "HAMSTER_turn_once_1": "말판", "HAMSTER_turn_once_2": "으로 한 번 돌기", "HAMSTER_turn_once_left": "왼쪽", "HAMSTER_turn_right": "오른쪽", "HAMSTER_move_forward": "앞으로 이동하기", "HAMSTER_move_backward": "뒤로 이동하기", "HAMSTER_turn_around_1": "", "HAMSTER_turn_around_2": "으로 돌기", "HAMSTER_move_forward_for_secs_1": "앞으로", "HAMSTER_move_forward_for_secs_2": "초 이동하기", "HAMSTER_move_backward_for_secs_1": "뒤로", "HAMSTER_move_backward_for_secs_2": "초 이동하기", "HAMSTER_turn_for_secs_1": "", "HAMSTER_turn_for_secs_2": "으로", "HAMSTER_turn_for_secs_3": "초 돌기", "HAMSTER_change_both_wheels_by_1": "왼쪽 바퀴", "HAMSTER_change_both_wheels_by_2": "오른쪽 바퀴", "HAMSTER_change_both_wheels_by_3": "만큼 바꾸기", "HAMSTER_set_both_wheels_to_1": "왼쪽 바퀴", "HAMSTER_set_both_wheels_to_2": "오른쪽 바퀴", "HAMSTER_set_both_wheels_to_3": "(으)로 정하기", "HAMSTER_change_wheel_by_1": "", "HAMSTER_change_wheel_by_2": "바퀴", "HAMSTER_change_wheel_by_3": "만큼 바꾸기", "HAMSTER_left_wheel": "왼쪽", "HAMSTER_right_wheel": "오른쪽", "HAMSTER_both_wheels": "양쪽", "HAMSTER_set_wheel_to_1": "", "HAMSTER_set_wheel_to_2": "바퀴", "HAMSTER_set_wheel_to_3": "(으)로 정하기", "HAMSTER_follow_line_using_1": "", "HAMSTER_follow_line_using_2": "선을", "HAMSTER_follow_line_using_3": "바닥 센서로 따라가기", "HAMSTER_left_floor_sensor": "왼쪽", "HAMSTER_right_floor_sensor": "오른쪽", "HAMSTER_both_floor_sensors": "양쪽", "HAMSTER_follow_line_until_1": "", "HAMSTER_follow_line_until_2": "선을 따라", "HAMSTER_follow_line_until_3": "교차로까지 이동하기", "HAMSTER_left_intersection": "왼쪽", "HAMSTER_right_intersection": "오른쪽", "HAMSTER_front_intersection": "앞쪽", "HAMSTER_rear_intersection": "뒤쪽", "HAMSTER_set_following_speed_to_1": "선 따라가기 속도를", "HAMSTER_set_following_speed_to_2": "(으)로 정하기", "HAMSTER_front": "앞쪽", "HAMSTER_rear": "뒤쪽", "HAMSTER_stop": "정지하기", "HAMSTER_set_led_to_1": "", "HAMSTER_set_led_to_2": "LED를", "HAMSTER_set_led_to_3": "으로 정하기", "HAMSTER_left_led": "왼쪽", "HAMSTER_right_led": "오른쪽", "HAMSTER_both_leds": "양쪽", "HAMSTER_clear_led_1": "", "HAMSTER_clear_led_2": "LED 끄기", "HAMSTER_color_cyan": "하늘색", "HAMSTER_color_magenta": "자주색", "HAMSTER_color_black": "검은색", "HAMSTER_color_white": "하얀색", "HAMSTER_color_red": "빨간색", "HAMSTER_color_yellow": "노란색", "HAMSTER_color_green": "초록색", "HAMSTER_color_blue": "파란색", "HAMSTER_beep": "삐 소리내기", "HAMSTER_change_buzzer_by_1": "버저 음을", "HAMSTER_change_buzzer_by_2": "만큼 바꾸기", "HAMSTER_set_buzzer_to_1": "버저 음을", "HAMSTER_set_buzzer_to_2": "(으)로 정하기", "HAMSTER_clear_buzzer": "버저 끄기", "HAMSTER_play_note_for_1": "", "HAMSTER_play_note_for_2": "", "HAMSTER_play_note_for_3": "음을", "HAMSTER_play_note_for_4": "박자 연주하기", "HAMSTER_rest_for_1": "", "HAMSTER_rest_for_2": "박자 쉬기", "HAMSTER_change_tempo_by_1": "연주 속도를", "HAMSTER_change_tempo_by_2": "만큼 바꾸기", "HAMSTER_set_tempo_to_1": "연주 속도를 분당", "HAMSTER_set_tempo_to_2": "박자로 정하기", "HAMSTER_set_port_to_1": "포트", "HAMSTER_set_port_to_2": "를", "HAMSTER_set_port_to_3": "으로 정하기", "HAMSTER_change_output_by_1": "출력", "HAMSTER_change_output_by_2": "를", "HAMSTER_change_output_by_3": "만큼 바꾸기", "HAMSTER_set_output_to_1": "출력", "HAMSTER_set_output_to_2": "를", "HAMSTER_set_output_to_3": "(으)로 정하기", "HAMSTER_port_a": "A", "HAMSTER_port_b": "B", "HAMSTER_port_ab": "A와 B", "HAMSTER_analog_input": "아날로그 입력", "HAMSTER_digital_input": "디지털 입력", "HAMSTER_servo_output": "서보 출력", "HAMSTER_pwm_output": "PWM 출력", "HAMSTER_digital_output": "디지털 출력", "ROBOID_acceleration_x": "x축 가속도", "ROBOID_acceleration_y": "y축 가속도", "ROBOID_acceleration_z": "z축 가속도", "ROBOID_back": "뒤쪽", "ROBOID_both": "양쪽", "ROBOID_button": "버튼", "ROBOID_buzzer": "버저", "ROBOID_clicked": "클릭했는가", "ROBOID_color_any": "아무 색", "ROBOID_color_black": "검은색", "ROBOID_color_blue": "파란색", "ROBOID_color_green": "초록색", "ROBOID_color_number": "색깔 번호", "ROBOID_color_orange": "주황색", "ROBOID_color_pattern": "색깔 패턴", "ROBOID_color_purple": "자주색", "ROBOID_color_red": "빨간색", "ROBOID_color_sky_blue": "하늘색", "ROBOID_color_violet": "보라색", "ROBOID_color_white": "하얀색", "ROBOID_color_yellow": "노란색", "ROBOID_double_clicked": "더블클릭했는가", "ROBOID_floor": "바닥 센서", "ROBOID_head": "머리", "ROBOID_head_color": "머리 색깔", "ROBOID_left": "왼쪽", "ROBOID_left_wheel": "왼쪽 바퀴", "ROBOID_long_pressed": "길게~눌렀는가", "ROBOID_note": "음표", "ROBOID_right": "오른쪽", "ROBOID_right_wheel": "오른쪽 바퀴", "ROBOID_sound_beep": "삐", "ROBOID_sound_birthday": "생일", "ROBOID_sound_dibidibidip": "디비디비딥", "ROBOID_sound_engine": "엔진", "ROBOID_sound_good_job": "잘 했어요", "ROBOID_sound_march": "행진", "ROBOID_sound_random_beep": "무작위 삐", "ROBOID_sound_robot": "로봇", "ROBOID_sound_siren": "사이렌", "ROBOID_tail": "꼬리", "ROBOID_unit_cm": "cm", "ROBOID_unit_deg": "도", "ROBOID_unit_pulse": "펄스", "ROBOID_unit_sec": "초", "ALBERT_hand_found": "손 찾음?", "ALBERT_is_oid_1": "", "ALBERT_is_oid_2": "OID 값이", "ALBERT_is_oid_3": "인가?", "ALBERT_front_oid": "앞쪽", "ALBERT_back_oid": "뒤쪽", "ALBERT_sensor_left_proximity": "왼쪽 근접 센서", "ALBERT_sensor_right_proximity": "오른쪽 근접 센서", "ALBERT_sensor_acceleration_x": "x축 가속도", "ALBERT_sensor_acceleration_y": "y축 가속도", "ALBERT_sensor_acceleration_z": "z축 가속도", "ALBERT_sensor_light": "밝기", "ALBERT_sensor_temperature": "온도", "ALBERT_sensor_battery": "배터리", "ALBERT_sensor_signal_strength": "신호 세기", "ALBERT_sensor_front_oid": "앞쪽 OID", "ALBERT_sensor_back_oid": "뒤쪽 OID", "ALBERT_sensor_position_x": "x 위치", "ALBERT_sensor_position_y": "y 위치", "ALBERT_sensor_orientation": "방향", "ALBERT_move_forward": "앞으로 이동하기", "ALBERT_move_backward": "뒤로 이동하기", "ALBERT_turn_around_1": "", "ALBERT_turn_around_2": "으로 돌기", "ALBERT_move_forward_for_secs_1": "앞으로", "ALBERT_move_forward_for_secs_2": "초 이동하기", "ALBERT_move_backward_for_secs_1": "뒤로", "ALBERT_move_backward_for_secs_2": "초 이동하기", "ALBERT_turn_for_secs_1": "", "ALBERT_turn_for_secs_2": "으로", "ALBERT_turn_for_secs_3": "초 돌기", "ALBERT_turn_left": "왼쪽", "ALBERT_turn_right": "오른쪽", "ALBERT_change_both_wheels_by_1": "왼쪽 바퀴", "ALBERT_change_both_wheels_by_2": "오른쪽 바퀴", "ALBERT_change_both_wheels_by_3": "만큼 바꾸기", "ALBERT_left_wheel": "왼쪽", "ALBERT_right_wheel": "오른쪽", "ALBERT_both_wheels": "양쪽", "ALBERT_set_both_wheels_to_1": "왼쪽 바퀴", "ALBERT_set_both_wheels_to_2": "오른쪽 바퀴", "ALBERT_set_both_wheels_to_3": "(으)로 정하기", "ALBERT_change_wheel_by_1": "", "ALBERT_change_wheel_by_2": "바퀴", "ALBERT_change_wheel_by_3": "만큼 바꾸기", "ALBERT_set_wheel_to_1": "", "ALBERT_set_wheel_to_2": "바퀴", "ALBERT_set_wheel_to_3": "(으)로 정하기", "ALBERT_stop": "정지하기", "ALBERT_set_board_size_to_1": "말판 크기를 폭", "ALBERT_set_board_size_to_2": "높이", "ALBERT_set_board_size_to_3": "(으)로 정하기", "ALBERT_move_to_x_y_1": "말판 x:", "ALBERT_move_to_x_y_2": "y:", "ALBERT_move_to_x_y_3": "위치로 이동하기", "ALBERT_set_orientation_to_1": "말판", "ALBERT_set_orientation_to_2": "방향으로 바라보기", "ALBERT_set_eye_to_1": "", "ALBERT_set_eye_to_2": "눈을", "ALBERT_set_eye_to_3": "으로 정하기", "ALBERT_left_eye": "왼쪽", "ALBERT_right_eye": "오른쪽", "ALBERT_both_eyes": "양쪽", "ALBERT_clear_eye_1": "", "ALBERT_clear_eye_2": "눈 끄기", "ALBERT_body_led_1": "몸통 LED", "ALBERT_body_led_2": "", "ALBERT_front_led_1": "앞쪽 LED", "ALBERT_front_led_2": "", "ALBERT_color_cyan": "하늘색", "ALBERT_color_magenta": "보라색", "ALBERT_color_white": "하얀색", "ALBERT_color_red": "빨간색", "ALBERT_color_yellow": "노란색", "ALBERT_color_green": "초록색", "ALBERT_color_blue": "파란색", "ALBERT_note_c": "도", "ALBERT_note_d": "레", "ALBERT_note_e": "미", "ALBERT_note_f": "파", "ALBERT_note_g": "솔", "ALBERT_note_a": "라", "ALBERT_note_b": "시", "ALBERT_turn_body_led_1": "몸통 LED", "ALBERT_turn_body_led_2": "", "ALBERT_turn_front_led_1": "앞쪽 LED", "ALBERT_turn_front_led_2": "", "ALBERT_turn_on": "켜기", "ALBERT_turn_off": "끄기", "ALBERT_beep": "삐 소리내기", "ALBERT_change_buzzer_by_1": "버저 음을", "ALBERT_change_buzzer_by_2": "만큼 바꾸기", "ALBERT_set_buzzer_to_1": "버저 음을", "ALBERT_set_buzzer_to_2": "(으)로 정하기", "ALBERT_clear_buzzer": "버저 끄기", "ALBERT_play_note_for_1": "", "ALBERT_play_note_for_2": "", "ALBERT_play_note_for_3": "음을", "ALBERT_play_note_for_4": "박자 연주하기", "ALBERT_rest_for_1": "", "ALBERT_rest_for_2": "박자 쉬기", "ALBERT_change_tempo_by_1": "연주 속도를", "ALBERT_change_tempo_by_2": "만큼 바꾸기", "ALBERT_set_tempo_to_1": "연주 속도를 분당", "ALBERT_set_tempo_to_2": "박자로 정하기", "VARIABLE_variable": "변수", "wall": "벽", "robotis_common_case_01": "(을)를", "robotis_common_set": "(으)로 정하기", "robotis_common_value": "값", "robotis_common_clockwhise": "시계방향", "robotis_common_counter_clockwhise": "반시계방향", "robotis_common_wheel_mode": "회전모드", "robotis_common_joint_mode": "관절모드", "robotis_common_red_color": "빨간색", "robotis_common_green_color": "녹색", "robotis_common_blue_color": "파란색", "robotis_common_on": "켜기", "robotis_common_off": "끄기", "robotis_common_cm": "제어기", "robotis_common_port_1": "포트 1", "robotis_common_port_2": "포트 2", "robotis_common_port_3": "포트 3", "robotis_common_port_4": "포트 4", "robotis_common_port_5": "포트 5", "robotis_common_port_6": "포트 6", "robotis_common_play_buzzer": "연주", "robotis_common_play_motion": "실행", "robotis_common_motion": "모션", "robotis_common_index_number": "번", "robotis_cm_custom": "직접입력 주소", "robotis_cm_spring_left": "왼쪽 접촉 센서", "robotis_cm_spring_right": "오른쪽 접촉 센서", "robotis_cm_led_left": "왼쪽 LED", "robotis_cm_led_right": "오른쪽 LED", "robotis_cm_led_both": "양 쪽 LED", "robotis_cm_switch": "선택 버튼 상태", "robotis_cm_user_button": "사용자 버튼 상태", "robotis_cm_sound_detected": "최종 소리 감지 횟수", "robotis_cm_sound_detecting": "실시간 소리 감지 횟수", "robotis_cm_ir_left": "왼쪽 적외선 센서", "robotis_cm_ir_right": "오른쪽 적외선 센서", "robotis_cm_calibration_left": "왼쪽 적외선 센서 캘리브레이션 값", "robotis_cm_calibration_right": "오른쪽 적외선 센서 캘리브레이션 값", "robotis_cm_clear_sound_detected": "최종소리감지횟수 초기화", "robotis_cm_buzzer_index": "음계값", "robotis_cm_buzzer_melody": "멜로디", "robotis_cm_led_1": "1번 LED", "robotis_cm_led_4": "4번 LED", "robotis_aux_servo_position": "서보모터 위치", "robotis_aux_ir": "적외선센서", "robotis_aux_touch": "접촉센서", "robotis_aux_brightness": "조도센서(CDS)", "robotis_aux_hydro_themo_humidity": "온습도센서(습도)", "robotis_aux_hydro_themo_temper": "온습도센서(온도)", "robotis_aux_temperature": "온도센서", "robotis_aux_ultrasonic": "초음파센서", "robotis_aux_magnetic": "자석센서", "robotis_aux_motion_detection": "동작감지센서", "robotis_aux_color": "컬러센서", "robotis_aux_custom": "사용자 장치", "robotis_carCont_aux_motor_speed_1": "감속모터 속도를", "robotis_carCont_aux_motor_speed_2": ", 출력값을", "robotis_carCont_calibration_1": "적외선 센서 캘리브레이션 값을", "robotis_openCM70_aux_motor_speed_1": "감속모터 속도를", "robotis_openCM70_aux_motor_speed_2": ", 출력값을", "robotis_openCM70_aux_servo_mode_1": "서보모터 모드를", "robotis_openCM70_aux_servo_speed_1": "서보모터 속도를", "robotis_openCM70_aux_servo_speed_2": ", 출력값을", "robotis_openCM70_aux_servo_position_1": "서보모터 위치를", "robotis_openCM70_aux_led_module_1": "LED 모듈을", "robotis_openCM70_aux_custom_1": "사용자 장치를", "XBOT_digital": "디지털", "XBOT_D2_digitalInput": "D2 디지털 입력", "XBOT_D3_digitalInput": "D3 디지털 입력", "XBOT_D11_digitalInput": "D11 디지털 입력", "XBOT_analog": "아날로그", "XBOT_CDS": "광 센서 값", "XBOT_MIC": "마이크 센서 값", "XBOT_analog0": "아날로그 0번 핀 값", "XBOT_analog1": "아날로그 1번 핀 값", "XBOT_analog2": "아날로그 2번 핀 값", "XBOT_analog3": "아날로그 3번 핀 값", "XBOT_Value": "출력 값", "XBOT_pin_OutputValue": "핀, 출력 값", "XBOT_High": "높음", "XBOT_Low": "낮음", "XBOT_Servo": "서보 모터", "XBOT_Head": "머리(D8)", "XBOT_ArmR": "오른 팔(D9)", "XBOT_ArmL": "왼 팔(D10)", "XBOT_angle": ", 각도", "XBOT_DC": "바퀴(DC) 모터", "XBOT_rightWheel": "오른쪽", "XBOT_leftWheel": "왼쪽", "XBOT_bothWheel": "양쪽", "XBOT_speed": ", 속도", "XBOT_rightSpeed": "바퀴(DC) 모터 오른쪽(2) 속도:", "XBOT_leftSpeed": "왼쪽(1) 속도:", "XBOT_RGBLED_R": "RGB LED 켜기 R 값", "XBOT_RGBLED_G": "G 값", "XBOT_RGBLED_B": "B 값", "XBOT_RGBLED_color": "RGB LED 색", "XBOT_set": "로 정하기", "XBOT_c": "도", "XBOT_d": "레", "XBOT_e": "미", "XBOT_f": "파", "XBOT_g": "솔", "XBOT_a": "라", "XBOT_b": "시", "XBOT_melody_ms": "초 연주하기", "XBOT_Line": "번째 줄", "XBOT_outputValue": "출력 값", "roborobo_num_analog_value_1": "아날로그", "roborobo_num_analog_value_2": "번 센서값", "roborobo_get_digital_value_1": "디지털", "roborobo_num_pin_1": "디지털", "roborobo_num_pin_2": "번 핀", "roborobo_on": "켜기", "roborobo_off": "끄기", "roborobo_motor1": "모터1", "roborobo_motor2": "모터2", "roborobo_motor_CW": "정회전", "roborobo_motor_CCW": "역회전", "roborobo_motor_stop": "정지", "roborobo_input_mode": "입력", "roborobo_output_mode": "출력", "roborobo_pwm_mode": "전류조절(pwm)", "roborobo_servo_mode": "서보모터", "roborobo_color": "컬러센서", "roborobo_color_red": " 빨간색 ", "roborobo_color_green": " 녹색 ", "roborobo_color_blue": " 파란색 ", "roborobo_color_yellow": " 노란색 ", "roborobo_color_detected": " 감지 ", "roborobo_degree": " ˚", "robotori_D2_Input": "디지털 2번 핀 입력 값", "robotori_D3_Input": "디지털 3번 핀 입력 값", "robotori_A0_Input": "아날로그 0번 핀 입력 값", "robotori_A1_Input": "아날로그 1번 핀 입력 값", "robotori_A2_Input": "아날로그 2번 핀 입력 값", "robotori_A3_Input": "아날로그 3번 핀 입력 값", "robotori_A4_Input": "아날로그 4번 핀 입력 값", "robotori_A5_Input": "아날로그 5번 핀 입력 값", "robotori_digital": "디지털", "robotori_D10_Output": "10번", "robotori_D11_Output": "11번", "robotori_D12_Output": "12번", "robotori_D13_Output": "13번", "robotori_pin_OutputValue": "핀, 출력 값", "robotori_On": "켜짐", "robotori_Off": "꺼짐", "robotori_analog": "아날로그", "robotori_analog5": "5번 핀 출력 값", "robotori_analog6": "6번 핀 출력 값", "robotori_analog9": "9번 핀 출력 값", "robotori_Servo": "서보모터", "robotori_DC": "DC모터", "robotori_DC_rightmotor": "오른쪽", "robotori_DC_leftmotor": "왼쪽", "robotori_DC_STOP": "정지", "robotori_DC_CW": "시계방향", "robotori_DC_CCW": "반시계방향", "robotori_DC_select": "회전", "CALC_rotation_value": "방향값", "CALC_direction_value": "이동 방향값", "VARIABLE_is_included_in_list": "리스트에 포함되어 있는가?", "VARIABLE_is_included_in_list_1": "", "VARIABLE_is_included_in_list_2": "에", "VARIABLE_is_included_in_list_3": "이 포함되어 있는가?", "SCENE_when_scene_start": "장면이 시작되었을때", "SCENE_start_scene_1": "", "SCENE_start_scene_2": "시작하기", "SCENE_start_neighbor_scene_1": "", "SCENE_start_neighbor_scene_2": "장면 시작하기", "SCENE_start_scene_pre": "이전", "SCENE_start_scene_next": "다음", "FUNCTION_explanation_1": "이름", "FUNCTION_character_variable": "문자/숫자값", "FUNCTION_logical_variable": "판단값", "FUNCTION_function": "함수", "FUNCTION_define": "함수 정의하기", "CALC_calc_operation_sin": "사인값", "CALC_calc_operation_cos": "코사인값", "CALC_calc_operation_tan": "탄젠트값", "CALC_calc_operation_floor": "소수점 버림값", "CALC_calc_operation_ceil": "소수점 올림값", "CALC_calc_operation_round": "반올림값", "CALC_calc_operation_factorial": "펙토리얼값", "CALC_calc_operation_asin": "아크사인값", "CALC_calc_operation_acos": "아크코사인값", "CALC_calc_operation_atan": "아크탄젠트값", "CALC_calc_operation_log": "로그값", "CALC_calc_operation_ln": "자연로그값", "CALC_calc_operation_natural": "정수 부분", "CALC_calc_operation_unnatural": "소수점 부분", "MOVING_locate_object_time_1": "", "MOVING_locate_object_time_2": "초 동안", "MOVING_locate_object_time_3": "위치로 이동하기", "wall_up": "위쪽 벽", "wall_down": "아래쪽 벽", "wall_right": "오른쪽 벽", "wall_left": "왼쪽 벽", "CALC_coordinate_x_value": "x 좌푯값", "CALC_coordinate_y_value": "y 좌푯값", "CALC_coordinate_rotation_value": "방향", "CALC_coordinate_direction_value": "이동방향", "CALC_picture_index": "모양 번호", "CALC_picture_name": "모양 이름", "FLOW_repeat_while_true_1": "", "FLOW_repeat_while_true_2": " 반복하기", "TUT_when_start": "프로그램 실행을 클릭했을때", "TUT_move_once": "앞으로 한 칸 이동", "TUT_rotate_left": "왼쪽으로 회전", "TUT_rotate_right": "오른쪽으로 회전", "TUT_jump_barrier": "장애물 뛰어넘기", "TUT_repeat_tutorial_1": "", "TUT_repeat_tutorial_2": "번 반복", "TUT_if_barrier_1": "만약 앞에", "TUT_if_barrier_2": " 이 있다면", "TUT_if_conical_1": "만약 앞에", "TUT_if_conical_2": " 이 있다면", "TUT_repeat_until": "부품에 도달할 때 까지 반복", "TUT_repeat_until_gold": "부품에 도달할 때 까지 반복", "TUT_declare_function": "함수 선언", "TUT_call_function": "함수 호출", "CALC_calc_operation_abs": "절댓값", "CONTEXT_COPY_option": "코드 복사", "Delete_Blocks": "코드 삭제", "Duplication_option": "코드 복사 & 붙여넣기", "Paste_blocks": "붙여넣기", "Clear_all_blocks": "모든 코드 삭제하기", "transparency": "투명도", "BRUSH_change_brush_transparency_1": "붓의 투명도를", "BRUSH_change_brush_transparency_2": "% 만큼 바꾸기", "BRUSH_set_brush_transparency_1": "붓의 투명도를", "BRUSH_set_brush_transparency_2": "% 로 정하기", "CALC_char_at_1": "", "CALC_char_at_2": "의", "CALC_char_at_3": "번째 글자", "CALC_length_of_string_1": "", "CALC_length_of_string_2": "의 글자 수", "CALC_substring_1": "", "CALC_substring_2": "의", "CALC_substring_3": "번째 글자부터", "length_of_string": "번째 글자부터", "CALC_substring_4": "번째 글자까지의 글자", "CALC_replace_string_1": "", "CALC_replace_string_2": "의", "CALC_replace_string_3": "을(를)", "CALC_replace_string_4": "로 바꾸기", "CALC_change_string_case_1": "", "CALC_change_string_case_2": "의", "CALC_change_string_case_3": " ", "CALC_change_string_case_sub_1": "대문자", "CALC_change_string_case_sub_2": "소문자", "CALC_index_of_string_1": "", "CALC_index_of_string_2": "에서", "CALC_index_of_string_3": "의 시작 위치", "MOVING_add_direction_by_angle_time_explain_1": "", "MOVING_direction_relative_duration_1": "", "MOVING_direction_relative_duration_2": "초 동안 이동 방향", "MOVING_direction_relative_duration_3": "만큼 회전하기", "CALC_get_sound_volume": " 소릿값", "SOUND_sound_from_to_1": "소리", "SOUND_sound_from_to_2": "", "SOUND_sound_from_to_3": "초 부터", "SOUND_sound_from_to_4": "초까지 재생하기", "SOUND_sound_from_to_and_wait_1": "소리", "SOUND_sound_from_to_and_wait_2": "", "SOUND_sound_from_to_and_wait_3": "초 부터", "SOUND_sound_from_to_and_wait_4": "초까지 재생하고 기다리기", "CALC_quotient_and_mod_1": "", "CALC_quotient_and_mod_2": "/", "CALC_quotient_and_mod_3": "의", "CALC_quotient_and_mod_4": "", "CALC_quotient_and_mod_sub_1": "몫", "CALC_quotient_and_mod_sub_2": "나머지", "self": "자신", "CALC_coordinate_size_value": "크기", "CALC_choose_project_timer_action_1": "초시계", "CALC_choose_project_timer_action_2": "", "CALC_choose_project_timer_action_sub_1": "시작하기", "CALC_choose_project_timer_action_sub_2": "정지하기", "CALC_choose_project_timer_action_sub_3": "초기화하기", "LOOKS_change_object_index_1": "", "LOOKS_change_object_index_2": "보내기", "LOOKS_change_object_index_sub_1": "맨 앞으로", "LOOKS_change_object_index_sub_2": "앞으로", "LOOKS_change_object_index_sub_3": "뒤로", "LOOKS_change_object_index_sub_4": "맨 뒤로", "FLOW_repeat_while_true_until": "이 될 때까지", "FLOW_repeat_while_true_while": "인 동안", "copy_block": "블록 복사", "delete_block": "블록 삭제", "tidy_up_block": "코드 정리하기", "block_hi": "안녕!", "entry_bot_name": "엔트리봇", "hi_entry": "안녕 엔트리!", "hi_entry_en": "Hello Entry!", "bark_dog": "강아지 짖는 소리", "walking_entryBot": "엔트리봇_걷기", "entry": "엔트리", "hello": "안녕", "nice": "반가워", "silent": "무음", "do_name": "도", "do_sharp_name": "도#(레♭)", "re_name": "레", "re_sharp_name": "레#(미♭)", "mi_name": "미", "fa_name": "파", "fa_sharp_name": "파#(솔♭)", "sol_name": "솔", "sol_sharp_name": "솔#(라♭)", "la_name": "라", "la_sharp_name": "라#(시♭)", "DUMMY": "더미", "coconut_stop_motor": "모터 정지", "coconut_move_motor": "움직이기", "coconut_turn_motor": "으로 돌기", "coconut_move_outmotor": "외부모터", "coconut_turn_left": "왼쪽", "coconut_turn_right": "오른쪽", "coconut_move_forward": "앞으로", "coconut_move_backward": "뒤로", "coconut_note_c": "도", "coconut_note_d": "레", "coconut_note_e": "미", "coconut_note_f": "파", "coconut_note_g": "솔", "coconut_note_a": "라", "coconut_note_b": "시", "coconut_move_speed_1": "0", "coconut_move_speed_2": "50", "coconut_move_speed_3": "100", "coconut_move_speed_4": "150", "coconut_move_speed_5": "255", "coconut_play_buzzer_hn": "2분음표", "coconut_play_buzzer_qn": "4분음표", "coconut_play_buzzer_en": "8분음표", "coconut_play_buzzer_sn": "16분음표", "coconut_play_buzzer_tn": "32분음표", "coconut_play_buzzer_wn": "온음표", "coconut_play_buzzer_dhn": "점2분음표", "coconut_play_buzzer_dqn": "점4분음표", "coconut_play_buzzer_den": "점8분음표", "coconut_play_buzzer_dsn": "점16분음표", "coconut_play_buzzer_dtn": "점32분음표", "coconut_rest_buzzer_hr": "2분쉼표", "coconut_rest_buzzer_qr": "4분쉼표", "coconut_rest_buzzer_er": "8분쉼표", "coconut_rest_buzzer_sr": "16분쉼표", "coconut_rest_buzzer_tr": "32분쉼표", "coconut_rest_buzzer_wr": "온쉼표", "coconut_play_midi_1": "반짝반짝 작은별", "coconut_play_midi_2": "곰세마리", "coconut_play_midi_3": "모차르트 자장가", "coconut_play_midi_4": "도레미송", "coconut_play_midi_5": "나비야", "coconut_floor_sensing_on": "감지", "coconut_floor_sensing_off": "미감지", "coconut_dotmatrix_set_on": "켜짐", "coconut_dotmatrix_set_off": "꺼짐", "coconut_dotmatrix_row_0": "모든", "coconut_dotmatrix_row_1": "1", "coconut_dotmatrix_row_2": "2", "coconut_dotmatrix_row_3": "3", "coconut_dotmatrix_row_4": "4", "coconut_dotmatrix_row_5": "5", "coconut_dotmatrix_row_6": "6", "coconut_dotmatrix_row_7": "7", "coconut_dotmatrix_row_8": "8", "coconut_dotmatrix_col_0": "모든", "coconut_dotmatrix_col_1": "1", "coconut_dotmatrix_col_2": "2", "coconut_dotmatrix_col_3": "3", "coconut_dotmatrix_col_4": "4", "coconut_dotmatrix_col_5": "5", "coconut_dotmatrix_col_6": "6", "coconut_dotmatrix_col_7": "7", "coconut_dotmatrix_col_8": "8", "coconut_sensor_left_proximity": "왼쪽 전방 센서", "coconut_sensor_right_proximity": "오른쪽 전방 센서", "coconut_sensor_both_proximity": "모든", "coconut_sensor_left_floor": "왼쪽 바닥센서", "coconut_sensor_right_floor": "오른쪽 바닥 센서", "coconut_sensor_both_floor": "모든", "coconut_sensor_acceleration_x": "x축 가속도", "coconut_sensor_acceleration_y": "y축 가속도", "coconut_sensor_acceleration_z": "z축 가속도", "coconut_sensor_light": "밝기", "coconut_sensor_temperature": "온도", "coconut_left_led": "왼쪽", "coconut_right_led": "오른쪽", "coconut_both_leds": "모든", "coconut_color_cyan": "하늘색", "coconut_color_magenta": "보라색", "coconut_color_black": "검은색", "coconut_color_white": "흰색", "coconut_color_red": "빨간색", "coconut_color_yellow": "노란색", "coconut_color_green": "초록색", "coconut_color_blue": "파란색", "coconut_beep": "삐 소리내기", "coconut_clear_buzzer": "버저 끄기", "coconut_x_axis": "X축", "coconut_y_axis": "Y축", "coconut_z_axis": "Z축", "modi_enviroment_bule": "파랑", "modi_enviroment_green": "초록", "modi_enviroment_humidity": "습도", "modi_enviroment_illuminance": "조도", "modi_enviroment_red": "빨강", "modi_enviroment_temperature": "온도", "modi_gyroscope_xAcceleratior": "X축 가속", "modi_gyroscope_yAcceleratior": "Y축 가속", "modi_gyroscope_zAcceleratior": "Z축 가속", "modi_motor_angle": "각도", "modi_motor_speed": "속도", "modi_motor_torque": "회전", "modi_speaker_F_DO_5": "도5", "modi_speaker_F_DO_6": "도6", "modi_speaker_F_DO_7": "도7", "modi_speaker_F_DO_S_5": "도#5", "modi_speaker_F_DO_S_6": "도#6", "modi_speaker_F_DO_S_7": "도#7", "modi_speaker_F_MI_5": "미5", "modi_speaker_F_MI_6": "미6", "modi_speaker_F_MI_7": "미7", "modi_speaker_F_PA_5": "파5", "modi_speaker_F_PA_6": "파6", "modi_speaker_F_PA_7": "파7", "modi_speaker_F_PA_S_5": "파#5", "modi_speaker_F_PA_S_6": "파#6", "modi_speaker_F_PA_S_7": "파#7", "modi_speaker_F_RA_5": "라5", "modi_speaker_F_RA_6": "라6", "modi_speaker_F_RA_7": "라7", "modi_speaker_F_RA_S_5": "라#5", "modi_speaker_F_RA_S_6": "라#6", "modi_speaker_F_RA_S_7": "라#7", "modi_speaker_F_RE_5": "레5", "modi_speaker_F_RE_6": "레6", "modi_speaker_F_RE_7": "레7", "modi_speaker_F_RE_S_5": "라#5", "modi_speaker_F_RE_S_6": "레#6", "modi_speaker_F_RE_S_7": "레#7", "modi_speaker_F_SOL_5": "솔5", "modi_speaker_F_SOL_6": "솔6", "modi_speaker_F_SOL_7": "솔7", "modi_speaker_F_SOL_S_5": "솔#5", "modi_speaker_F_SOL_S_6": "솔#6", "modi_speaker_F_SOL_S_7": "솔#7", "modi_speaker_F_SO_5": "시5", "modi_speaker_F_SO_6": "시6", "modi_speaker_F_SO_7": "시7", "si_name": "시", "ev3_ccw": "반시계", "ev3_cw": "시계", "rokoboard_sensor_name_0": "소리", "rokoboard_sensor_name_1": "빛", "rokoboard_sensor_name_2": "슬라이더", "rokoboard_sensor_name_3": "저항-A", "rokoboard_sensor_name_4": "저항-B", "rokoboard_sensor_name_5": "저항-C", "rokoboard_sensor_name_6": "저항-D", "rokoboard_string_1": "버튼을 눌렀는가?", "HW_MOTOR": "모터", "HW_SENSOR": "센서", "HW_LED": "발광다이오드", "HW_MELODY": "멜로디", "HW_ROBOT": "로봇", "ALTINO_ACCX": "가속도 X축", "ALTINO_ACCY": "가속도 Y축", "ALTINO_ACCZ": "가속도 Z축", "ALTINO_BAT": "배터리 잔량 체크", "ALTINO_CDS": "밝기", "ALTINO_GYROX": "자이로 X축", "ALTINO_GYROY": "자이로 Y축", "ALTINO_GYROZ": "자이로 Z축", "ALTINO_IR1": "1번 거리", "ALTINO_IR2": "2번 거리", "ALTINO_IR3": "3번 거리", "ALTINO_IR4": "4번 거리", "ALTINO_IR5": "5번 거리", "ALTINO_IR6": "6번 거리", "ALTINO_Led_Brake_Light": "브레이크", "ALTINO_Led_Forward_Light": "전방", "ALTINO_Led_Reverse_Light": "후방", "ALTINO_Led_Turn_Left_Light": "왼쪽방향", "ALTINO_Led_Turn_Right_Light": "오른쪽방향", "ALTINO_Line": "번째 줄", "ALTINO_MAGX": "나침판 X축", "ALTINO_MAGY": "나침판 Y축", "ALTINO_MAGZ": "나침판 Z축", "ALTINO_REMOTE": "리모콘 수신 값", "ALTINO_STTOR": "조향 토크", "ALTINO_STVAR": "조향 가변저항", "ALTINO_Steering_Angle_Center": "가운데", "ALTINO_Steering_Angle_Left10": "왼쪽10", "ALTINO_Steering_Angle_Left15": "왼쪽15", "ALTINO_Steering_Angle_Left20": "왼쪽20", "ALTINO_Steering_Angle_Left5": "왼쪽5", "ALTINO_Steering_Angle_Right10": "오른쪽10", "ALTINO_Steering_Angle_Right15": "오른쪽15", "ALTINO_Steering_Angle_Right20": "오른쪽20", "ALTINO_Steering_Angle_Right5": "오른쪽5", "ALTINO_TEM": "온도", "ALTINO_TOR1": "오른쪽 토크", "ALTINO_TOR2": "왼쪽 토크", "ALTINO_Value": "출력 값", "ALTINO_a": "라", "ALTINO_a2": "라#", "ALTINO_b": "시", "ALTINO_c": "도", "ALTINO_c2": "도#", "ALTINO_d": "레", "ALTINO_d2": "레#", "ALTINO_dot_display_1": "한문자", "ALTINO_dot_display_2": "출력하기", "ALTINO_e": "미", "ALTINO_f": "파", "ALTINO_f2": "파#", "ALTINO_g": "솔", "ALTINO_g2": "솔#", "ALTINO_h": "끄기", "ALTINO_h2": "켜기", "ALTINO_leftWheel": "왼쪽", "ALTINO_melody_ms": "연주하기", "ALTINO_outputValue": "출력 값", "ALTINO_rightWheel": "오른쪽", "ALTINO_set": "로 정하기", "ardublock_motor_forward": "앞", "ardublock_motor_backward": "뒤", "mkboard_dc_motor_forward": "앞", "mkboard_dc_motor_backward": "뒤", "jdkit_clockwise": "시계방향", "jdkit_counterclockwise": "반시계방향", "jdkit_gyro_frontrear": "앞뒤", "jdkit_gyro_leftright": "좌우", "jdkit_joystick_leftleftright": "왼쪽 좌우", "jdkit_joystick_lefttopbottom": "왼쪽 상하", "jdkit_joystick_rightleftright": "오른쪽 좌우", "jdkit_joystick_righttopbottom": "오른쪽 상하", "jdkit_led": "LED", "jdkit_led_color_green": "초록색", "jdkit_led_color_orange": "오랜지색", "jdkit_led_turnoff": "끄기", "jdkit_led_turnon": "켜기", "jdkit_motor_leftbottom": "왼쪽아래", "jdkit_motor_lefttop": "왼쪽위", "jdkit_motor_rightbottom": "오른쪽아래", "jdkit_motor_righttop": "오른쪽위", "jdkit_tune_do": "도", "jdkit_tune_fa": "파", "jdkit_tune_la": "라", "jdkit_tune_mi": "미", "jdkit_tune_re": "레", "jdkit_tune_si": "시", "jdkit_tune_sol": "솔" }; Lang.Buttons = { "lesson_list": "강의 목록", "complete_study": "학습 완료하기", "show_me": "미리 보기", "do_this_for_me": "대신 해주기", "previous": "이전", "get_started": "시작하기", "next_lesson": "다음 내용 학습하기", "course_submit": "제출하기", "course_done": "확인", "mission": "미션 확인하기", "basic_guide": "기본 사용 방법", "apply": "적용하기", "cancel": "취소", "save": "확인", "start": "시작", "confirm": "확인", "delete": "삭제", "create": "학급 만들기", "done": "완료", "accept": "수락", "refuse": "거절", "yes": "예", "button_no": "아니오", "quiz_retry": "다시 풀어보기", "discuss_upload": "불러오기", "maze_popup_guide": "이용안내", "maze_popup_mapHint": "힌트보기", "maze_hint_btn_guide": "이용 안내", "maze_hint_btn_block": "블록 도움말", "maze_hint_btn_map": "힌트 보기", "maze_hint_btn_goal": "목표" }; Lang.ko = "한국어"; Lang.vn = "tiếng Việt"; Lang.Menus = { "enterPassword": "비밀번호를 입력해주세요.", "enterNewPassword": "새로운 비밀번호를 입력하세요.", "reEnterNewPassword": "새로운 비밀번호를 다시 입력하세요.", "revokeTitle": "개인정보 복구", "revokeDesc1": "1년 이상 사이트에 로그인 하시지 않아", "revokeDesc2": "회원님의 개인정보가 분리 보관 중입니다.", "revokeDesc3": "분리 보관 중인 개인정보를 복구하시려면", "revokeDesc4": "[복구하기] 버튼을 눌러주세요.", "revokeButton": "복구하기", "revokeComplete": "개인정보 복구가 완료되었습니다.", "resign": "회원탈퇴", "check_sended_email": "발송된 인증 메일을 확인하여 이메일 주소를 인증해 주세요.", "signUpEmail_1": "입력된 이메일 주소로 인증 메일이 발송되었습니다.", "signUpEmail_2": "이메일 주소를 인증해주세요.", "enter_password_withdraw": "회원탈퇴 신청을 위해 비밀번호를 입력해주세요.", "instruction_agree": "안내 사항에 동의해주세요.", "check_instructions": "위 안내 사항에 동의합니다.", "deleteAccount_2": "회원탈퇴를 신청하신 30일 이후에는 회원정보와 작품/강의/학급/게시글/댓글/좋아요/관심 정보가 모두 삭제되며 복구가 불가능합니다.", "deleteAccount_1": "회원탈퇴를 신청하신 30일 이내에 로그인하시면 회원탈퇴를 취소하실 수 있습니다.", "protect_account": "안전한 비밀번호로 내정보를 보호하세요.", "please_verify": "인증 메일을 발송하여 이메일 주소를 인증해 주세요.", "unverified_email": "이메일 주소가 인증되지 않았습니다.", "verifying_email": "인증 메일 발송", "deleteAccount": "회원탈퇴 신청", "corporatePersonal": "개인정보 이전에 동의 합니다", "corporateTransferGuide": "개인정보 양수자('엔트리' 웹사이트 운영자) 안내", "corporateReciever": "개인정보를 이전 받은 자: 재단법인 커넥트", "corporateAddress": "커넥트 주소 및 연락처", "corporateAddress_1": "서울시 강남구 강남대로 382 메리츠타워 7층", "corporateConsent": "개인정보의 이전을 원치 않으시는 경우 ,동의 철회 방법", "corporateEmail": "계정에 등록된 이메일로 탈퇴 요청 메일 발송", "corporateAddition": "또한 , 영업 양도에 따라 약관 등이 아래와 같이 변경될 예정입니다.", "corporateApplicationDate": "적용시기 : 2017년 10월 29일", "corporateTargetChanges": "적용대상 및 변경사항 :", "corporateTarget": "적용대상", "corporateChanges": "변경사항", "corporateTerms": "엔트리 이용약관", "corporateOperator": "웹사이트 운영자의 명칭 변경", "corporateClassroomTerms": "학급 서비스 이용약관", "doAgreeWithClassroomTerms": "학급 서비스 이용약관에 동의합니다.", "doChangePassword": "나만 알수 있는 비밀번호로 변경해주세요.", "corporatePrivacyPolicy": "개인정보 처리방침", "corporateConsignment": "웹사이트 운영자의 명칭 변경 및 개인정보 위탁 업체 추가", "corporateEntrusted": "수탁업: NHN Technology Service(주)", "corporateConsignmentDetails": "위탁업무 내용: 서비스 개발 및 운영", "corporatePeriod": "보유기간 : 회원 탈퇴 시 혹은 위탁 계약 종료시 까지", "corporateChangeDate": "변경 적용일 : 2017년 10월 29일 부", "corporateWarning": "개인정보 이전에 동의해 주세요.", "corporateConfirm": "확인", "corporateTitle": "안녕하세요. 엔트리교육연구소입니다. <br>“엔트리”를 이용하고 계신 회원 여러분께 깊은 감사의 말씀을 드립니다.<br> 엔트리교육연구소는 그동안 공익 목적으로 운영해오던 “엔트리” 웹사이트의 운영을<br> 네이버가 설립한 비영리 재단인 커넥트재단에 양도하기로 합의하였습니다. <br>앞으로 엔트리는 커넥트재단에서 공익 목적 하에 지속적으로 운영될 수 있도록 <br>할 것이며, 회원 여러분께서는 기존과 동일하게 엔트리를 이용하실 수 있습니다.<br> 웹사이트 제공 주체가 엔트리교육연구소에서 커넥트재단으로 변경됨에 따라 아래와 <br>같이 회원 개인 정보에 대한 이전이 있으며, 본 합의에 의해 실제 개인 정보의 위치가 <br>물리적으로 이동한 것은 아님을 알려드립니다. ", "textcoding_numberError_v": "등록된 변수 중에 이름의 첫 글자가 숫자인 변수가 있으면 모드 변환을 할 수 없습니다.", "textcoding_bookedError_1v": "등록된 변수 중에 변수 이름이 ", "textcoding_bookedError_2v": " 인 변수가 있으면 모드 변환을 할 수 없습니다.", "textcoding_specialCharError_v": "등록된 변수 중 이름에 '_' 를 제외한 특수 문자가 있으면 모드 변환을 할 수 없습니다.", "textcoding_numberError_l": "등록된 리스트 중에 이름의 첫 글자가 숫자인 리스트가 있으면 모드 변환을 할 수 없습니다.", "textcoding_bookedError_1l": "등록된 리스트 중에 리스트 이름이", "textcoding_bookedError_2l": "인 리스트가 있으면 모드 변환을 할 수 없습니다.", "textcoding_specialCharError_l": "등록된 리스트 중 이름에 '_' 를 제외한 특수 문자가 있으면 모드 변환을 할 수 없습니다.", "no_discuss_permission": "글을 읽을 권한이 없습니다", "delete_comment": "댓글을 삭제하시겠습니까?", "delete_article": "게시물을 삭제하시겠습니까?", "discuss_cannot_edit": "본인의 게시물이 아닙니다.", "discuss_extention": "실행파일은 첨부하실 수 없습니다.", "delete_discuss_picture": "사진을 삭제하시겠습니까?", "delete_discuss_file": "파일을 삭제하시겠습니까?", "discuss_save_question": "글을 저장하시겠습니까?", "discuss_cancle_question": "작성을 취소하시겠습니까?", "discuss_saved": "이 저장되었습니다.", "discuss_no_write_permission": "현재 로그인된 계정으로는 글을 작성하실 수 없습니다.", "discuss_no_project_permission": "현재 로그인된 계정으로는 작품을 게시하실 수 없습니다.", "discuss_write_abuse_detected": "짧은 시간안에 여러 글이 작성되었습니다.\n10분 뒤에 다시 시도해주세요.", "discuss_write_abuse_warn": "짧은 시간안에 여러 댓글을 작성하는 경우 \n댓글 작성이 제한될 수 있습니다. \n이용에 주의하시길 바랍니다.", "search_lang": "검색", "search_title": "제목", "faq_desc": "엔트리를 이용하면서 궁금한 점들의 답변을 확인해보세요.", "faq_all": "전체보기", "faq_site": "사이트 이용", "faq_project": "작품 만들기", "faq_hardware": "하드웨어", "faq_offline": "오프라인", "faq_copyright": "저작권", "faq_title": "자주하는 질문", "faq": "자주하는 질문", "fword_alert_1": "주제와 무관한 욕설이나 악플은 게시할 수 없습니다.", "fword_alert_2": "불건전한 단어가 포함되어 있어, 대체 문장으로 게시 됩니다.", "fword_replace_1": "엔트리를 통해 누구나 쉽고 재미있게 소프트웨어를 배울 수 있어요.", "fword_replace_2": "소프트웨어 교육의 첫걸음, 엔트리.", "fword_replace_3": "재미있게 배우는 학습 공간 엔트리!", "fword_replace_4": "엔트리에서 공유와 협업을 통해 멋진 작품을 만들어요.", "fword_replace_5": "엔트리는 누구나 무료로 소프트웨어 교육을 받을 수 있게 개발된 소프트웨어 교육 플랫폼입니다.", "fword_replace_6": "엔트리와 함께 건강한 소프트웨어 교육 생태계를 조성해요!", "fword_replace_7": "엔트리에서 학습하고, 만들고, 공유하며 같이 성장해요.", "solve_quiz": "퀴즈 풀기", "submit_homework_first_title": "완성! 과제 제출하기", "submit_homework_first_content": "멋진 작품이 완성되었습니다. 과제를 제출하세요. 마감 기한 전까지 다시 제출할 수 있습니다.", "submit_homework_again_title": "과제 다시 제출하기", "submit_homework_again_content": "이미 제출한 과제입니다.<br>과제를 다시 제출하시겠습니까?", "submit_homework_expired_title": "과제 제출 마감", "submit_homework_expired_content": "과제 제출이 마감되었습니다.", "done_study_title": "완성", "done_study_content": "만든 작품을 실행해 봅시다.", "featured_courses": "추천 강의 모음", "follow_along": "따라하기", "follow_along_desc": "차근차근 따라하며 다양한 작품을 만듭니다.", "do_quiz": "퀴즈풀기", "do_quiz_desc": "학습한 내용을 잘 이해했는지 퀴즈를 통해 확인합니다.", "challenge": "도전하기", "play": "도전하기", "challenge_desc": "주어진 문제를 스스로 해결하며 개념을 익힙니다.", "creste_freely": "자유롭게 만들기", "creste_freely_desc": "학습한 내용으로 나만의 작품을 자유롭게 만듭니다.", "entry_rc_desc": "프로그래밍의 원리를 학습단계에 맞게 배울 수 있는 엔트리 강의 모음! 지금 시작해보세요!<br>따라하고, 도전하며 소프트웨어를 만들다 보면 어렵게 느껴졌던 프로그래밍의 원리도 쉽고 재미있게 다가옵니다!", "hw_deadline": "마감 일자", "rc_course_desc": "프로그래밍의 원리를 학습단계에 맞게 배울 수 있도록 구성된 엔트리 강의 모음입니다.", "rc_course": "추천 강의 모음", "entry_rec_course": "엔트리 추천 강의 모음", "entry_rec_course_desc": "누구나 쉽게 보고 따라하면서 재미있고 다양한 소프트웨어를 만들 수 있는 엔트리 강의를 소개합니다.", "guidance": "안내", "wait": "잠깐", "hint": "힌트", "concept_guide": "개념 톡톡", "group_quiz": "우리 반 퀴즈", "fail_check_hint": "앗… 실패! 다시 한 번 도전해보세요!<br>어려울 땐 [힌트]를 확인해보세요!", "sort_student": "학생별", "sort_lesson": "강의별", "sort_course": "강의 모음별", "student_progress": "우리 반 진도", "my_progress": "나의 진도", "lec_in_progress": "학습 중", "free_modal_asgn_over": "과제 제출이 마감되었습니다.", "free_submission_closed": "과제 제출 마감", "free_modal_asgn_submit_first": "멋진 작품이 완성되었습니다! 과제를 제출하세요.<br>마감 기한 전까지 다시 제출 할 수 있습니다.", "asgn_submit": "완성! 과제 제출하기", "free_modal_content_resubmit": "이미 제출한 과제입니다.<br>과제를 다시 제출하시겠습니까?", "asgn_resubmit": "과제 다시 제출하기", "free_modal_content_complete": "멋진 작품이 완성되었습니다.", "guide_modal_content_complete": "만든 작품을 실행해 봅시다.", "success": "성공", "fail": "실패", "mission_modal_content_fail": "<br>어려울 땐 [힌트]를 확인해보세요!", "mission_modal_content_success": "만든 작품을 실행해 봅시다.", "in_progress": "진행중", "completed": "완료", "submitted": "제출 완료", "submission_closed": "마감", "progress": "진행 상황", "study_completed": "학습 완료", "view_course_desc": "코스웨어 설명 보기", "main_entry_starter": "기초부터! 엔트리 스타터", "main_entry_booster": "개념탄탄! 엔트리 부스터", "main_entry_master": "생각을 펼치는! 엔트리 마스터", "no_students_in_classroom": "아직 등록된 학생이 없습니다.<br>학생을 직접 추가하거나, 초대해 보세요!", "lectures": "강의", "Lectures": "강의", "studentHomeworkList": "과제", "curriculums": "강의 모음", "Curriculums": "강의 모음", "quiz": "퀴즈", "no_added_group_contents_teacher": "추가된 %1이(가) 없습니다. <br>우리 반 %1을(를) 추가해 주세요.", "no_added_group_contents_student": "아직 올라온 %1이(가) 없습니다. 선생님이 %1을(를) 올려주시면, 학습 내용을 확인할 수 있습니다.", "side_project": "보조 프로젝트", "custom_make_course_1": "'오픈 강의 만들기> 강의 모음 만들기'에서", "custom_make_course_2": "나만의 강의 모음을 만들어 보세요.", "custom_make_lecture_1": "'오픈 강의 만들기'에서", "custom_make_lecture_2": "나만의 강의를 만들어 보세요", "alert_enter_info": "수정할 정보를 입력해주세요.", "alert_enter_new_pwd": "기존 비밀번호와 다른 비밀번호를 입력해주세요.", "alert_match_pwd": "새로운 비밀번호와 재입력된 비밀번호가 일치하지 않습니다.", "alert_check_pwd": "비밀번호를 확인해주세요.", "no_group_contents_each_prefix": "우리반 ", "no_group_contents_each_suffix": " 이(가) 없습니다.", "no_group_contents_all": "학급에 올라온 컨텐츠가 없습니다.<br>학급 공유하기에<br>나만의 작품을 공유해보세요!", "hw_closed": "과제 마감", "tag_Lecture": "강의", "tag_Curriculum": "강의모음", "tag_Discuss": "공지", "count_ko": "개", "no_asgn_within_week": "1주일안에 제출되어야 하는 마감 임박한 과제가 없습니다.", "lecture_and_curriculum": "강의 / 강의 모음", "assignments_plural": "과제", "assignments_singular": "과제", "project_plural": "작품", "group_news": "새로운 소식", "stu_management": "학생 관리", "stu_management_camel": "학생 관리", "view_all": "전체 보기", "view_all_camel": "전체 보기", "view_contents_camel": "콘텐츠 보기", "view_contents": "콘텐츠 보기", "no_updated_news": "나의 학급에 올라온 새로운 소식이 없습니다.", "homework_soon_due": "곧 마감 과제", "new_homework": "최신 과제", "no_new_homework": "새로운 과제가 없습니다.", "student_plural": "학생", "discuss": "공지", "basic_project": "기본 작품", "no_permission": "권한이 없습니다.", "original_curriculum_deleted": "원본 강의 모음이 삭제되었습니다.", "original_curriculum": "원본 강의 모음", "save_as_my_lecture": "복사본으로 저장하기 ", "delete_confirm": "삭제 알림", "lecture_open_as_copied": "오픈 강의 페이지에 올라간 모든 강의는 사본으로 생성되어 공개 됩니다.", "curriculum_open_as_copied": "오픈 강의 모음 페이지에 올라간 모든 강의 모음은 사본으로 생성되어 공개 됩니다.", "lecture_save_as_copied_group": "우리 반 강의 페이지에 올라간 모든 강의는 사본으로 생성되어 공개 됩니다.", "curriculum_save_as_copied_group": "우리 반 강의 모음 페이지에 올라간 모든 강의 모음은 사본으로 생성되어 공개 됩니다.", "homework_save_as_copied_group": "우리 반 과제 페이지에 올라간 모든 과제는 사본으로 생성되어 공개 됩니다.", "lecture_save_as_copied": "내가 만든 강의 모음 안에 삽입된 구성 강의는 사본으로 생성되어 저장됩니다.", "done_project_save_as_copied": "내가 만든 강의 안에 삽입된 완성 작품은 사본으로 생성되어 저장됩니다.", "original_lecture_deleted": "원본 강의가 삭제되었습니다.", "original_lecture": "원본 강의", "lecture_save_as_mine_alert": "저장되었습니다.\n저장된 강의는 '마이페이지> 나의 강의'에서 확인할 수 있습니다.", "lecture_save_as_mine": "내 강의로 저장하기", "duplicate_username": "이미 입력한 아이디 입니다.", "share_your_project": "내가 만든 작품을 공유해 보세요", "not_available_student": "학급에서 발급된 '학급 아이디'입니다.\n'엔트리 회원 아이디'를 입력해주세요.", "login_instruction": "로그인 안내", "login_needed": "로그인 후 이용할 수 있습니다.", "login_as_teacher": "선생님 계정으로 로그인 후 이용할 수 있습니다.", "submit_hw": "과제 제출하기", "success_goal": "목표성공", "choseok_final_result": "좋아 , 나만의 작품을 완성했어!", "choseok_fail_msg_timeout": "시간이 너무 많이 지나버렸어. 목표를 잘 보고 다시 한번 도전해봐!", "choseok_fail_msg_die": "생명이 0이하인데 게임이 끝나지 않았어.\n아래의 블록을 사용해서 다시 도전해 보는 건 어때?", "grade_1": "초급", "grade_2": "중급", "grade_3": "고급", "find_sally_title": "샐리를 찾아서", "save_sally_title": "샐리 구하기", "exit_sally_title": "샐리 탈출하기", "find_sally": "라인 레인저스의 힘을 모아 \n강력한 악당 메피스토를 물리치고 샐리를 구해주세요!", "save_sally": "메피스토 기지에 갇힌 샐리. \n라인 레인저스가 장애물을 피해 샐리를 찾아갈 수 있도록\n도와주세요!", "exit_sally": "폭파되고 있는 메피스토 기지에서 \n샐리와 라인 레인저스가 무사히 탈출할 수 있도록\n도와주세요!", "go_next_mission": "다른 미션 도전하기", "share_my_project": "내가 만든 작품 공유하기", "share_certification": "인증서 공유하기", "print_certification": "인증서를 뽐내봐", "get_cparty_events": "내가 받은 인증서를 출력해 뽐내면 푸짐한 상품을 받을 수 있어요!", "go_cparty_events": "이벤트 참여하러 가기", "codingparty2016_blockHelper_1_title": "앞으로 가기", "codingparty2016_blockHelper_1_contents": "앞으로 가기", "codingparty2016_blockHelper_2_title": "앞으로 가기", "codingparty2016_blockHelper_2_contents": "회전하기", "codingparty2016_blockHelper_3_title": "앞으로 가기", "codingparty2016_blockHelper_3_contents": "돌 부수기", "codingparty2016_blockHelper_4_title": "앞으로 가기", "codingparty2016_blockHelper_4_contents": "횟수 반복하기", "codingparty2016_blockHelper_5_title": "앞으로 가기", "codingparty2016_blockHelper_5_contents": "꽃 던지기", "codingparty2016_goalHint_1": "샐리를 구하기 위해서는 미네랄이 필요해! 미네랄을 얻으며 목적지까지 가보자!", "codingparty2016_goalHint_2": "구불구불한 길이 있네. 회전 블록을 사용하면 어렵지 않을 거야!", "codingparty2016_goalHint_3": "앞이 돌로 막혀있잖아? 돌을 부수며 목적지까지 가보자!", "codingparty2016_goalHint_4": "복잡한 길이지만 지금까지 배운 것들로 해결할 수 있어!", "codingparty2016_goalHint_5": "앞으로 쭉 가는 길이잖아? 반복 블록을 사용하여 간단하게 해결해 보자!", "codingparty2016_goalHint_6": "미네랄을 모두 모아오자. 반복블록을 쓰면 쉽게 다녀올 수 있겠어!", "codingparty2016_goalHint_7": "친구들이 다치지 않도록 꽃을 던져 거미집을 제거해야 해. 저 멀리 있는 거미집을 제거하고 목적지까지 가 보자.", "codingparty2016_goalHint_8": "가는 길에 거미집이 많잖아? 거미집을 모두 제거하고 목적지까지 가 보자.", "codingparty2016_goalHint_9": "거미집 뒤쪽에 있는 미네랄을 모두 모아오자!", "codingparty2016_guide_1_1_contents": "라인 레인저스 전사들이 샐리를 구할 수 있도록 도와줘! 전사들을 움직이기 위해서는 블록 명령어를 조립해야 해.\n\n① 먼저 미션 화면과 목표를 확인하고,\n② 블록 꾸러미에서 필요한 블록을 가져와 “시작하기를 클릭했을 때“ 블록과 연결해.\n③ 다 조립되면 ‘시작하기‘ 버튼을 눌러 봐! 블록이 위에서부터 순서대로 실행되며 움직일 거야.", "codingparty2016_guide_1_1_title": "라인 레인저스 전사들을 움직이려면?", "codingparty2016_guide_1_2_title": "목표 블록의 개수", "codingparty2016_guide_1_2_contents": "① [안 칠해진 별]의 개수만큼 블록을 조립해 미션을 해결해보자. 목표 블록보다 더 많은 블록을 사용하면 별이 빨간색으로 바뀌니 정해진 개수 안에서 문제를 해결해 봐!\n② 필요하지 않은 블록은 휴지통 또는 블록꾸러미에 넣어줘.", "codingparty2016_guide_1_3_title": "'앞으로 가기' 블록을 사용하기", "codingparty2016_guide_1_3_contents": "< 앞으로 가기 > 는 앞으로 한 칸 이동하는 블록이야. \n\n여러 칸을 이동하기 위해서는 이 블록을 여러 번 연결해야 해.", "codingparty2016_guide_1_4_title": "미네랄 획득하기", "codingparty2016_guide_1_4_contents": "[ 미네랄 ]이 있는 곳을 지나가면 미네랄을 획득할 수 있어\n\n화면에 있는 미네랄을 모두 획득하고 목적지에 도착해야만 다음 단계로 넘어갈 수 있어.", "codingparty2016_guide_1_5_title": "어려울 때 도움을 받으려면?", "codingparty2016_guide_1_5_contents": "미션을 수행하다가 어려울 땐 3가지 종류의 도움말 버튼을 눌러 봐.\n\n\n<안내> 지금 이 안내를 다시 보고 싶을 때!\n<블록 도움말> 블록 하나하나가 어떻게 동작하는지 궁금할 때!\n<맵 힌트> 이 단계를 해결하기 위한 힌트가 필요할 때!", "codingparty2016_guide_2_1_title": "회전 블록 사용하기", "codingparty2016_guide_2_1_contents": "<오른쪽으로 돌기>와 <왼쪽으로 돌기>는 \n제자리에서 90도 회전하는 블록이야. 방향만 회전하는 블록이야. \n캐릭터가 바라보고 있는 방향을 기준으로 오른쪽인지 왼쪽인지 잘 생각해 봐!\n", "codingparty2016_guide_3_1_title": "(문) 능력 사용하기", "codingparty2016_guide_3_1_contents": "라인 레인저스 전사들을 각자의 능력을 가지고 있어.\n나 [문] 은 <발차기하기> 로 바로 앞에 있는 [돌]을 부술 수 있어.\n[돌을] 부수고 나면 막힌 길을 지나갈 수 있겠지?\n화면에 있는 [돌]을 모두 제거해야만 다음 단계로 넘어갈 수 있어.\n그렇지만 명심해! 아무 것도 없는 곳에 능력을 낭비해서는 안 돼!", "codingparty2016_guide_5_1_title": "'~번 반복하기' 블록 사용하기", "codingparty2016_guide_5_1_contents": "똑같은 일을 반복해서 명령하는 건 매우 귀찮은 일이야.\n이럴 땐 명령을 사용하면 훨씬 쉽게 명령을 내릴 수 있어. \n< [ ? ] 번 반복하기> 블록 안에 반복되는 명령 블록을 넣고 \n[ ? ] 부분에 횟수를 입력하면 입력한 횟수만큼 같은 명령을 반복하게 돼.", "codingparty2016_guide_5_2_title": "'~번 반복하기' 블록 사용하기", "codingparty2016_guide_5_2_contents": "'< [ ? ] 번 반복하기> 블록 안에는 여러 개의 명령어를 넣을 수도 있으니 잘 활용해봐! \n도착지에 도착했더라도 반복하기 블록 안에 있는 블록이 모두 실행돼.\n 즉, 위 상황에서 목적지에 도착한 후에도 왼쪽으로 돈 다음에야 끝나는 거야!", "codingparty2016_guide_7_1_title": "(코니) 능력 사용하기", "codingparty2016_guide_7_1_contents": "나 ‘코니’는 <꽃 던지기>로 먼 거리에서도 앞에 있는 [거미집]을 없앨 수 있어.\n[거미집]을 없애고 나면 막힌 길을 지나갈 수 있겠지?\n화면에 있는 [거미집]을 모두 제거해야만 다음 단계로 넘어갈 수 있어.\n그렇지만 명심해! 아무것도 없는 곳에 능력을 낭비해서는 안 돼!", "codingparty2016_guide_9_1_title": "조건 반복 블록 사용하기", "codingparty2016_guide_9_1_contents": "반복하는 횟수를 세지 않아도, 어떤 조건을 만족할 때까지 행동을 반복할 수 있어.\n< [목적지]에 도착할 때까지 반복하기 > 블록 안에 반복되는 명령 블록을 넣으면 [목적지]에 도착할 때까지 명령을 반복해.", "codingparty2016_guide_9_2_title": "조건 반복 블록 사용하기", "codingparty2016_guide_9_2_contents": "<[목적지]에 도착할 때까지 반복하기> 블록 안에는 여러 개의 명령어를 넣을 수도 있으니 잘 활용해봐!\n 도착지에 도착했더라도 반복하기 블록 안에 있는 블록이 모두 실행 돼. 즉, 위 상황에서 목적지에 도착한 후에도 왼쪽으로 돈 다음에야 끝나는 거야!", "find_interesting_lesson": "'우리 반 강의'에서 다양한 강의를 만나보세요!", "find_interesting_course": "'우리 반 강의 모음'에서 다양한 강의를 만나보세요!", "select_share_settings": "공유 공간을 선택해주세요.", "faq_banner_title": "자주하는 질문 안내", "check_out_faq": "궁금한 점을 확인하세요.", "faq_banner_content": "엔트리에 대해 궁금하세요?<br />자주하는 질문을 통해 답변을 드리고 있습니다.<br />지금 바로 확인하세요!", "faq_banner_button": "자주하는 질문<br />바로가기", "major_updates": "주요 업데이트 안내", "check_new_update": "엔트리의 변화를 확인하세요.", "major_updates_notification": "엔트리의 주요 변경사항을 공지를 통해 안내해 드리고 있습니다.", "find_out_now": "지금 바로 확인하세요!", "offline_hw_program": "오프라인 & 하드웨어 연결 프로그램", "read_more": "자세히 보기", "not_supported_function": "이 기기에서는 지원하지 않는 기능입니다.", "offline_download_confirm": "엔트리 오프라인 버전은 PC에서만 이용가능합니다. 다운로드 하시겠습니까?", "hardware_download_confirm": "엔트리 하드웨어는 PC에서만 이용가능합니다. 다운로드 하시겠습니까?", "copy_text": "텍스트를 복사하세요.", "select_openArea_space": "작품 공유 공간을 선택해 주세요", "mission_guide": "미션 해결하기 안내", "of": " 의", "no_results_found": "검색 결과가 없습니다.", "upload_pdf": "PDF 자료 업로드", "select_basic_project": "작품 선택하기", "try_it_out": "만들어 보기", "go_boardgame": "엔트리봇 보드게임 바로가기", "go_cardgame": "엔트리봇 카드게임 바로가기", "go_solve": "미션으로 학습하기", "go_ws": "엔트리 만들기 바로가기", "go_arts": "엔트리 공유하기 바로가기", "group_delete_alert": "학급을 삭제하면, 해당 학급에서 발급한 학생임시계정을 포함하여 관련한 모든 자료가 삭제됩니다.\n정말 삭제하시겠습니까?", "view_arts_list": "다른 작품 보기", "hw_submit_confirm_alert": "과제가 제출 되었습니다.", "hw_submit_alert": "과제를 제출 하시겠습니까? ", "hw_submit_alert2": "과제를 제출하시겠습니까? 제출 시 진행한 학습 단계까지만 제출이 됩니다.", "hw_submit_cannot": "제출 할 수 없는 과제입니다.", "see_other_missions": "다른 미션 보기", "project": " 작품", "marked": " 관심", "group": "학급", "lecture": "강의", "Lecture": "강의", "curriculum": "강의 모음", "Curriculum": "강의 모음", "studying": "학습 중인", "open_only_shared_lecture": "<b>오픈 강의</b> 페이지에 <b><공개></b> 한 강의만 불러올 수 있습니다. 불러오고자 하는 <b>강의</b>의 <b>공개여부</b>를 확인해 주세요.", "already_exist_group": "이미 존재하는 학급 입니다.", "cannot_invite_you": "자기 자신을 초대할 수 없습니다.", "apply_original_image": "원본 이미지 그대로 적용하기", "draw_new_ques": "새로 그리기 페이지로\n이동하시겠습니까?", "draw_new_go": "이동하기", "draw_new_stay": "이동하지 않기", "file_upload_desc_1": "이런 그림은 \n 안돼요!", "file_upload_desc_2": "피가 보이고 잔인한 그림", "file_upload_desc_3": "선정적인 신체노출의 그림", "file_upload_desc_4": "욕이나 저주 등의 불쾌감을 주거나 혐오감을 일으키는 그림", "file_upload_desc_5": "* 위와 같은 내용은 이용약관 및 관련 법률에 의해 제재를 받으실 수 있습니다.", "picture_upload_warn_1": "10MB 이하의 jpg, png, bmp 형식의 파일을 추가할 수 있습니다.", "sound_upload_warn_1": "10MB 이하의 mp3 형식의 파일을 추가할 수 있습니다.", "lesson_by_teacher": "선생님들이 직접 만드는 강의입니다.", "delete_group_art": "학급 공유하기 목록에서 삭제 하시겠습니까?", "elementary_short": "초등", "middle_short": "중등", "share_lesson": "강의 공유하기", "share_course": "강의 모음 공유하기", "from_list_ko": "을(를)", "comming_soon": "준비중입니다.", "no_class_alert": "선택된 학급이 없습니다. 학급이 없는경우 '나의 학급' 메뉴에서 학급을 만들어 주세요.", "students_cnt": "명", "defult_class_alert_1": "", "defult_class_alert_2": "을(를) \n 기본학급으로 설정하시겠습니까?", "default_class": "기본학급입니다.", "enter_hw_name": "과제의 제목을 입력해 주세요.", "hw_limit_20": "과제는 20개 까지만 만들수 있습니다.", "stu_example": "예)\n 홍길동\n 홍길동\n 홍길동", "hw_description_limit_200": "생성 과제에 대한 안내 사항을 입력해 주세요. (200자 이내)", "hw_title_limit_50": "과제명을 입력해 주세요. (50자 이내)", "create_project_class_1": "'만들기 > 작품 만들기' 에서", "create_project_class_2": "학급에 공유하고 싶은 작품을 만들어 주세요.", "create_lesson_assignment_1": "'만들기> 오픈 강의 만들기'에서 ", "create_lesson_assignment_2": "우리 반 과제에 추가하고 싶은 강의를 만들어 주세요.", "i_make_lesson": "내가 만드는 강의", "lesson_to_class_1": "'학습하기>오픈 강의'에서 우리반", "lesson_to_class_2": "과제에 추가하고 싶은 강의를 관심강의로 등록해 주세요.", "studying_students": "학습자", "lessons_count": "강의수", "group_out": "나가기", "enter_group_code": "학급코드 입력하기", "no_group_invite": "학급 초대가 없습니다.", "done_create_group": "개설이 완료되었습니다.", "set_default_group": "기본학급 설정", "edit_group_info": "학급 정보 관리", "edit_done": "수정 완료되었습니다.", "alert_group_out": "학급을 정말 나가시겠습니까?", "lesson_share_cancel": "강의 공유 취소", "project_share_cancel": "작품 공유 취소", "lesson_share_cancel_alert": "이(가) 공유된 모든 공간에서 공유를 취소하고 <나만보기>로 변경하시겠습니까? ", "lesson_share_cancel_alert_en": "", "course_share_cancel": "강의 모음 공유 취소", "select_lesson_share": "강의 공유 공간 선택", "select_project_share": "작품 공유 선택", "select_lesson_share_policy_1": "강의를 공유할", "select_lesson_share_policyAdd": "공간을 선택해 주세요", "select_lesson_share_project_1": "작품을 공유할 공간과", "select_lesson_share_policy_2": "저작권 정책을 확인해 주세요.", "select_lesson_share_area": "강의 공유 공간을 선택해 주세요", "select_project_share_area": "작품 공유 공간을 선택해 주세요", "lesson_share_policy": "강의 공유에 따른 엔트리 저작권 정책 동의", "project_share_policy": "작품 공유에 따른 엔트리 저작권 정책 동의", "alert_agree_share": "공개하려면 엔트리 저작물 정책에 동의하여야 합니다.", "alert_agree_all": "모든 항목에 동의해 주세요.", "select_course_share": "강의 모음 공유 공간 선택", "select_course_share_policy_1": "강의 모음을 공유할", "select_course_share_policy_2": "저작권 정책을 확인해 주세요.", "select_course_share_area": "강의 모음 공유 공간을 선택해 주세요", "course_share_policy": "강의 모음 공유에 따른 엔트리 저작권 정책 동의", "issued": "발급", "code_expired": "코드가 만료되었습니다. '코드재발급' 버튼를 누르세요.", "accept_class_invite": "학급초대 수락하기", "welcome_class": "학급에 오신것을 환영합니다.", "enter_info": "자신의 정보를 입력해주세요.", "done_group_signup": "학급 가입이 완료되었습니다.", "enter_group_code_stu": "선생님께 받은 코드를 입력해주세요.", "text_limit_50": "50글자 이하로 작성해 주세요.", "enter_class_name": "학급 이름을 입력해 주세요.", "enter_grade": "학년을 입력해 주세요.", "enter_class_info": "학급소개를 입력해 주세요.", "student_dup": "은(는) 이미 학급에 존재합니다.", "select_stu_print": "출력할 학생을 선택하세요.", "class_id_not_exist": "학급 ID가 존재하지 않습니다.", "error_try_again": "오류 발생. 다시 한 번 시도해 주세요.", "code_not_available": "유효하지 않은 코드입니다.", "gnb_create_lessons": "오픈 강의 만들기", "study_lessons": "강의 학습하기", "lecture_help_1": "학습을 시작할 때, 사용할 작품을 선택해 주세요. 선택한 작품으로 학습자가 학습을 시작하게 됩니다.", "lecture_help_2": "이도움말을 다시 보시려면 위 버튼을 클릭해 주세요.", "lecture_help_3": "오브젝트 추가하기가 없으면새로운 오브젝트를 추가하거나 삭제 할 수 없습니다.", "lecture_help_4": "학습도중에 PDF자료보기를 통해 학습에 도움을 받을 수 있습니다.", "lecture_help_5": "학습에 필요한 블록들만 선택해주세요. 선택하지 않은 블록은 숨겨집니다.", "lecture_help_6": "블록코딩과 엔트리파이선 중에 선택하여 학습환경을 구성할 수 있습니다.", "only_pdf": ".pdf형식의 파일만 입력 가능합니다.", "enter_project_video": "적어도 하나의 작품이나 영상을 입력하세요.", "enter_title": "제목을 입력하세요.", "enter_recommanded_grade": "추천 학년을 입력하세요.", "enter_level_diff": "난이도를 입력하세요.", "enter_time_spent": "소요시간을 입력하세요.", "enter_shared_area": "적어도 하나의 공유 공간을 선택하세요.", "enter_goals": "학습목표를 입력하세요.", "enter_lecture_description": "강의 설명을 입력하세요.", "enter_curriculum_description": "강의 모음 설명을 입력하세요.", "first_page": "처음 입니다.", "last_page": "마지막 입니다.", "alert_duplicate_lecture": "이미 등록된 강의는 다시 등록할 수 없습니다.", "enter_lesson_alert": "하나 이상의 강의를 등록해주세요.", "open_edit_lessons": "편집할 강의를 불러오세요.", "saved_alert": "이(가) 저장되었습니다.", "select_lesson_type": "어떤 학습과정을 만들지 선택해 주세요 ", "create_lesson": "강의 만들기", "create_lesson_desc_1": "원하는 학습 목표에 맞춰", "create_lesson_desc_2": "단일 강의를 만들어", "create_lesson_desc_3": "학습에 활용합니다.", "create_courseware": "강의 모음 만들기", "create_courseware_desc_1": "학습 과정에 맞춰 여러개의 강의를", "create_courseware_desc_2": "하나의 코스로 만들어", "create_courseware_desc_3": "학습에 활용합니다.", "create_open_lesson": "오픈 강의 만들기 ", "enter_lesson_info": "강의 정보 입력 ", "select_lesson_feature": "학습 기능 선택 ", "check_info_entered": "입력 정보 확인 ", "enter_lefo_lesson_long": "강의를 구성하는 정보를 입력해 주세요.", "lesson_info_desc": "학습자가 학습하기 화면에서 사용할 기능과 작품을 선택함으로써, 학습 목표와 내용에 최적화된 학습환경을 구성할 수 있습니다.", "provide_only_used": "완성된 작품에서 사용된 블록만 불러오기", "see_help": "도움말 보기", "select_done_project_1": "학습자가 목표로 설정할", "select_done_project_2": "완성 작품", "select_done_project_3": "을 선택해 주세요.", "select_project": "나의 작품 또는 관심 작품을 불러옵니다. ", "youtube_desc": "유투브 공유 링크를 통해 원하는 영상을 넣을 수 있습니다.", "lesson_video": "강의 영상", "lesson_title": "강의 제목", "recommended_grade": "추천학년", "selection_ko": "선택", "selection_en": "", "level_of_diff": "난이도", "select_level_of_diff": "난이도 선택", "enter_lesson_title": "강의 제목을 입력해 주세요(30자 이내)", "select_time_spent": "소요시간 선택 ", "time_spent": "소요시간", "lesson_overview": "강의설명", "upload_materials": "학습 자료 업로드", "open": "불러오기", "cancel": "취소하기", "upload_lesson_video": "강의 영상 업로드", "youtube_upload_desc": "유투브 공유링크를 통해 보조영상을 삽입할 수 있습니다. ", "cancel_select": "선택 취소하기", "select_again": "다시 선택하기", "goal_project": "완성작품", "upload_study_data": "학습하기 화면에서 볼 수 있는 학습자료를 업로드해주세요. 학습자가 업로드된 학습자료의 내용을 확인하며 학습할 수 있습니다. ", "upload_limit_20mb": "20MB 이하의 파일을 올려주세요.", "expect_time": "예상 소요 시간", "course_videos": "보조 영상", "enter_courseware_info": "강의 모음 정보 입력 ", "enter_course_info": "강의 모음을 소개하는 정보를 입력해 주세요 ", "select_lessons_for_course": "강의 모음을 구성하는 강의를 선택해 주세요.", "course_build_desc_1": "강의는", "course_build_desc_2": "최대30개", "course_build_desc_3": "등록할 수 있습니다.", "lseeon_list": "강의 목록 보기", "open_lessons": "강의 불러오기", "course_title": "강의 모음 제목", "title_limit_30": "강의 모음 제목을 입력해 주세요(30자 이내) ", "course_overview": "강의 모음 설명", "charactert_limit_200": "200자 이내로 작성할 수 있습니다.", "edit_lesson": "강의 편집", "courseware_by_teacher": "선생님들이 직접 만드는 강의 모음입니다.", "select_lessons": "구성 강의 선택", "check_course_info": "강의 모음을 구성하는 정보가 올바른지 확인해 주세요.", "select_share_area": "공유 공간 선택", "upload_sub_project": "보조 프로젝트 업로드", "file_download": "첨부파일 다운로드", "check_lesson_info": "강의를 구성하는 정보가 올바른지 확인해 주세요.", "share_area": "공유 공간", "enter_sub_project": "엔트리 보조 프로젝트를 등록해 주세요.", "lms_hw_title": "과제 제목", "lms_hw_ready": "준비", "lms_hw_progress": "진행중", "lms_hw_complete": "완료", "lms_hw_not_submit": "미제출", "lms_hw_closed": "제출마감", "submission_condition": "진행중인 과제만 제출이 가능합니다.", "submit_students_only": "학생만 과제를 제출할 수 있습니다.", "want_submit_hw": "과제를 제출하시겠습니까?", "enter_correct_id": "올바른 아이디를 입력해 주세요.", "id_not_exist": "아이디가 존재하지 않습니다. ", "agree_class_policy": "학급 서비스 이용약관에 동의해 주세요.", "delete_class": "학급 삭제", "type_stu_name": "학생 이름을 입력해주세요. ", "invite_from_1": "에서", "invite_from_2": "님을 초대하였습니다. ", "lms_pw_alert_1": "학급에 소속되면, 선생님 권한으로", "lms_pw_alert_2": "비밀번호 재발급이 가능합니다.", "lms_pw_alert_3": "선생님의 초대가 맞는지 한번 더 확인해주세요.", "invitation_accepted": "초대 수락이 완료되었습니다!", "cannot_issue_pw": "초대를 수락하지 않았으므로 비밀번호를 발급할 수 없습니다.", "start_me_1": "<월간 엔트리>와 함께", "start_me_2": "SW교육을 시작해보세요!", "monthly_desc_1": "<월간 엔트리>는 소프트웨어 교육에 익숙하지 않은 선생님들도 쉽고 재미있게", "monthly_desc_2": "소프트웨어 교육을 하실 수 있도록 만들어진 SW교육 잡지입니다.", "monthly_desc_3": "매월 재미있는 학습만화와 함께 하는 SW 교육 컨텐츠를 만나보세요!", "monthly_desc_4": "* 월간엔트리는 2015년 11월 ~ 2016년 5월까지 발행 후 중단되었습니다.", "monthly_desc_5": "엔트리의 교육자료는 교육자료 페이지에서 만나보세요.", "monthly_entry": "월간 엔트리", "me_desc_1": "매월 발간되는 무료 소프트웨어 교육잡지", "me_desc_2": "월간엔트리를 만나보세요!", "solve_desc_1": "게임을 하듯 미션을 해결하며", "solve_desc_2": "소프트웨어의 기본 원리를 배워보세요!", "playSw_desc_1": "EBS 방송영상, 특별영상을 통해", "playSw_desc_2": "소프트웨어를 배워보세요!", "recommended_lessons": "추천 강의 모음", "recommended_lessons_1": "따라하고, 도전하고, 퀴즈도 풀며 재미있게 엔트리 프로그래밍을 배워보세요!", "recommended_lessons_2": "추천 강의 모음을 만나보세요!", "offline_top_desc_1": "오프라인 버전의 저장 기능이 향상되고 보안이 강화되었습니다.", "offline_top_desc_2": "지금 바로 다운받으세요", "offline_main_desc": "엔트리 오프라인 에디터 업데이트!!", "art_description": "엔트리로 만든 작품을 공유하는 공간입니다. 작품을 만들고 공유에 참여해 보세요.", "study_index": "엔트리에서 제공하는 주제별, 학년별 학습과정을 통해 차근차근 소프트웨어를 배워보세요!", "study_for_beginner": "처음 시작하는 사람들을 위한 엔트리 첫걸음", "entrybot_desc_3": "안내에 따라 블록 명령어를 조립하여", "entrybot_desc_4": "엔트리봇을 학교에 데려다 주세요.", "move_entrybot": "엔트리봇 움직이기", "can_change_entrybot_1": "블록 명령어로 엔트리봇의 색을 바꾸거나", "can_change_entrybot_2": "말을 하게 할 수도 있어요.", "learning_process_by_topics": "주제별 학습과정", "show_detail": "자세히 보기", "solve_mission": "미션 해결하기", "solve_mission_desc_1": "게임을 하듯 미션을 해결하며 프로그래밍의 원리를 익혀보세요!", "solve_mission_desc_2": "미로 속의 엔트리봇을 목적지까지 움직이며 순차, 반복, 선택, 비교연산 등의 개념을 자연스럽게 익힐 수 있어요.", "learning_process_by_grades": "학년별 학습과정", "learning_process_by_grades_sub1": "4가지 유형으로 쉽고 재미있게 배우는 프로그래밍의 원리! 지금 시작해보세요!", "e3_to_e4": "초등 3-4 학년", "e5_to_e6": "초등 5-6 학년", "m1_to_m3": "중등 이상", "make_using_entry": "엔트리로 만들기", "make_using_entry_desc_1": "블록을 쌓아 여러 가지 소프트웨어를 만들어보세요!", "make_using_entry_desc_2": "제공되는 교재를 다운받아 차근차근 따라하다보면 애니메이션, 미디어아트, 게임 등 다양한 작품을 만들 수 있어요.", "make_through_ebs_1": "EBS 방송영상으로 소프트웨어를 배워보세요.", "make_through_ebs_2": "방송영상은 물론, 차근차근 따라 할 수 있는 특별영상과 함께 누구나 쉽게 다양한 소프트웨어를 만들 수 있어요.", "support_block_js": "블록 코딩과 자바스크립트 언어를 모두 지원합니다.", "study_ebs_title_1": "순서대로! 차례대로!", "study_ebs_desc_1": "[실습] 엔트리봇의 심부름", "study_ebs_title_2": "쉽고 간단하게!", "study_ebs_desc_2": "[실습] 꽃송이 만들기", "study_ebs_title_3": "언제 시작할까?", "study_ebs_desc_3": "[실습] 동물가족 소개", "study_ebs_title_4": "다른 선택, 다른 결과!", "study_ebs_desc_4": "[실습] 텔레파시 게임", "study_ebs_title_5": "정보를 담는 그릇", "study_ebs_desc_5": "[실습] 덧셈 로봇 만들기", "study_ebs_title_6": "요모조모 따져 봐!", "study_ebs_desc_6": "[실습] 복불복 룰렛", "study_ebs_title_7": "번호로 부르면 편해요!", "study_ebs_desc_7": "[실습] 나만의 버킷리스트", "study_ebs_title_8": "무작위 프로그램을 만들어라!", "study_ebs_desc_8": "[실습] 무작위 캐릭터 만들기", "study_ebs_title_9": "어떻게 찾을까?", "study_ebs_desc_9": "[실습] 도서관 책 검색", "study_ebs_title_10": "줄을 서시오!", "study_ebs_desc_10": "[실습] 키 정렬 프로그램", "event": "이벤트", "divide": "분기", "condition": "조건", "random_number": "무작위수", "search": "탐색", "sorting": "정렬", "parallel": "병렬", "signal": "신호", "input_output": "입출력", "sequential": "순차", "repeat": "반복", "choice": "선택", "repeat_advanced": "반복(횟수+조건)", "function": "함수", "compare_operation": "비교연산", "arithmetic": "산술연산", "entry_recommended_mission": "엔트리 추천 미션", "more_mission": "더 많은 미션 보러가기", "line_rangers_title": "라인레인저스와\n샐리 구하기", "line_rangers_content": "메피스토 기지에 갇힌\n샐리를 구해주세요!", "pinkbean_title": "핑크빈과 함께 신나는\n메이플 월드로!", "pinkbean_content": "핑크빈이 메이플 월드 모험을\n무사히 마칠 수 있도록 도와주세요.", "entrybot_school": "엔트리봇 학교 가는 길", "entrybot_school_desc_1": "엔트리봇이 책가방을 챙겨 학교에", "entrybot_school_desc_2": "도착할 수 있도록 도와주세요!", "robot_factory": "로봇 공장", "robot_factory_desc_1": "로봇공장에 갇힌 엔트리봇!", "robot_factory_desc_2": "탈출하기 위해 부품을 모두 모아야해요.", "electric_car": "전기 자동차", "electric_car_desc_1": "엔트리봇 자동차가 계속 앞으로 나아갈 수", "electric_car_desc_2": "있도록 연료를 충전해 주세요.", "forest_adventure": "숲속 탐험", "forest_adventure_desc_1": "엔트리봇 친구가 숲속에 갇혀있네요!", "forest_adventure_desc_2": "친구를 도와주세요.", "town_adventure": "마을 탐험", "town_adventure_desc_1": "배고픈 엔트리봇을 위해 마을에 있는", "town_adventure_desc_2": "연료를 찾아주세요.", "space_trip": "우주 여행", "space_trip_desc_1": "우주탐사를 마친 엔트리봇!", "space_trip_desc_2": "지구로 돌아갈 수 있도록 도와주세요.", "learn_programming_mission": "미션을 해결하며 배우는 프로그래밍", "make_open_lecture": "오픈 강의 만들기", "group_created": "만든 학급", "group_signup": "가입한 학급", "delete_from_list": "을(를) 목록에서 삭제하시겠습니까?", "delete_from_list_en": "", "lecture_collection": "강의 모음", "edit_mypage_profile": "자기소개 정보 관리", "main_image": "메인 이미지", "edit_profile_success": "반영되었습니다.", "no_project_1": "내가 만든 작품이 없습니다.", "no_project_2": "지금 작품 만들기를 시작해보세요!", "no_marked_project_1": "관심 작품이 없습니다.", "no_marked_project_2": "'작품 공유하기'에서 다양한 작품을 만나보세요!", "no_markedGroup_project_2": "'학급 공유하기'에서 다양한 작품을 만나보세요!", "view_project_all": "작품 구경하기", "no_lecture_1": "내가 만든 강의가 없습니다.", "no_lecture_2": "'오픈 강의 만들기'에서 강의를 만들어보세요!", "no_marked_lecture_1": "관심 강의가 없습니다.", "no_marked_lecture_2": "'오픈 강의'에서 다양한 강의를 만나보세요!", "view_lecture": "강의 살펴보기", "no_studying_lecture_1": "학습 중인 강의가 없습니다.", "no_studying_lecture_2": "'오픈 강의'에서 학습을 시작해보세요!", "no_lecture_collect_1": "내가 만든 강의 모음이 없습니다.", "no_lecture_collect_2": "'오픈 강의 모음 만들기'에서 강의 모음을 만들어보세요!", "make_lecture_collection": "강의 모음 만들기", "no_marked_lecture_collect_1": "관심 강의 모음이 없습니다.", "no_marked_lecture_collect_2": "'오픈 강의'에서 다양한 강의를 만나보세요!", "view_lecture_collection": "강의 모음 살펴보기", "no_studying_lecture_collect_1": "학습 중인 강의 모음이 없습니다.", "no_studying_lecture_collect_2": "'오픈 강의'에서 학습을 시작해보세요!", "my_lecture": "나의 강의", "markedGroup": "학급 관심", "markedGroup_lecture": "학급 관심 강의", "markedGroup_curriculum": "학급 관심 강의모음", "marked_lecture": "관심 강의", "marked_lecture_collection": "나의 관심 강의 모음", "marked_marked_curriculum": "관심 강의 모음", "studying_lecture": "학습 중인 강의", "completed_lecture": "학습 완료 강의", "my_lecture_collection": "나의 강의 모음", "my": "나의", "studying_lecture_collection": "학습 중인 강의 모음", "completed_lecture_collection": "학습 완료한 강의 모음", "my_curriculum": "나의 강의 모음", "studying_curriculum": "학습 중인 강의 모음", "completed_curriculum": "학습 완료한 강의 모음", "materialCC": "엔트리에서 제공하는 모든 교육 자료는 CC-BY 2.0 라이선스에 따라 자유롭게 이용할 수 있습니다.", "pdf": "PDF", "helper": "도움말", "youtube": "영상", "tvcast": "영상", "goal": "목표", "basicproject": "시작단계", "hw": "하드웨어", "object": "오브젝트", "console": "콘솔", "download_info": "모든 교육자료는 각각의 제목을 클릭 하시면 다운받으실 수 있습니다.", "entry_materials_all": "엔트리 교육자료 모음", "recommand_grade": "추천학년", "g3_4_grades": "3-4 학년", "g5_6_grades": "5-6 학년", "middle_grades": "중학생 이상", "entry_go_go": "엔트리 고고!", "entry_go_go_desc": "학년별, 난이도 별로 준비된 교재를 만나보세요. 각 과정별로 교육과정, 교재, 교사용 지도자료 3종 세트가 제공됩니다.", "stage_beginner": "초급", "stage_middle": "중급", "stage_high": "고급", "middle_school_short": "중등", "learn_entry_programming": "따라하며 배우는 엔트리 프로그래밍", "entry_programming_desc": "차근차근 따라 하다 보면 어느새 나도 엔트리 고수!", "ebs": "EBS", "ebs_material_desc": "방송 영상과 교사용 지도서를 활용하여 수업을 해보세요!", "season_1_material": "시즌1 교사용 지도서", "season_2_material": "시즌2 교사용 지도서", "compute_think_textbook": "교과서로 배우는 컴퓨팅 사고력", "computational_sw": "국어, 수학, 과학, 미술... 학교에서 배우는 다양한 교과와 연계하여 sw를 배워보세요!", "entry_x_hardware": "엔트리 X 하드웨어 교육자료 모음", "e_sensor": "E 센서보드", "e_sensor_board": "E 센서보드", "e_sensor_robot": "E 센서로봇", "arduino": "아두이노", "arduinoExt": "아두이노 Uno 확장모드", "arduinoNano": "아두이노 Nano", "orange_board": "오렌지보드", "joystick": "조이스틱 센서 쉴드", "ardublock": "아두블럭", "mkboard": "몽키보드", "memaker": "미메이커", "edumaker": "에듀메이커 보드", "codingtoolbox": "코딩툴박스", "materials_etc_all": "기타 교육자료 모음", "materials_teaching": "교원 연수 자료", "materials_etc": "기타 참고 자료", "materials_teaching_1": "SW교육의 필요성과 교육 방법론", "materials_teaching_2": "엔트리와 함께하는 언플러그드 활동", "materials_teaching_3": "게임하듯 알고리즘을 배우는 엔트리 미션 해결하기", "materials_teaching_4": "실생활 문제해결을 위한 엔트리 프로그래밍", "materials_teaching_5": "교과연계 SW교육1 (미술,수학,사회)", "materials_teaching_6": "교과연계 SW교육2 (국어,과학,음악)", "materials_teaching_7": "피지컬 컴퓨팅 실습1(E센서보드)", "materials_teaching_8": "피지컬 컴퓨팅 실습2(햄스터)", "materials_teaching_9": "수업에 필요한 학급/강의 기능 알아보기", "materials_etc_1": "엔트리 첫 사용자를 위한 스타트 가이드", "materials_etc_2": "수업에 바로 활용할 수 있는 다양한 콘텐츠 모음집", "materials_etc_3": "월간 엔트리", "materials_etc_4": "엔트리 설명서", "materials_etc_5": "엔트리 소개 자료", "materials_etc_6": "엔트리 블록 책받침", "materials_etc_7": "엔트리파이선 예제 및 안내", "jr_if_1": "만약", "jr_if_2": "앞에 있다면", "jr_fail_no_pencil": "이런 그곳에는 연필이 없어. 연필이 있는 곳에서 사용해보자~", "jr_fail_forgot_pencil": "앗! 책가방에 넣을 연필을 깜빡했어. 연필을 모아서 가자~", "jr_fail_much_blocks": "너무많은 블록을 사용했어, 다시 도전해볼래?", "cparty_jr_success_1": "좋아! 책가방을 챙겼어!", "go_right": "오른쪽", "go_down": " 아래쪽", "go_up": " 위쪽", "go_left": " 왼쪽", "go_forward": "앞으로 가기", "jr_turn_left": "왼쪽으로 돌기", "jr_turn_right": "오른쪽으로 돌기", "go_slow": "천천히 가기", "repeat_until_reach_1": "만날 때 까지 반복하기", "repeat_until_reach_2": "", "pick_up_pencil": "연필 줍기", "repeat_0": "", "repeat_1": "반복", "when_start_clicked": "시작 버튼을 눌렀을 때", "age_0": "작품체험", "create_character": "캐릭터 만들기", "age_7_9": "초등 저학년", "going_school": "엔트리 학교가기", "age_10_12_1": "초등 고학년1", "collect_parts": "로봇공장 부품모으기", "age_10_12_2": "초등 고학년2", "driving_elec_car": "전기자동차 운전하기", "age_13": "중등", "travel_space": "우주여행하기", "people": "사람", "all": "전체", "life": "일상생활", "nature": "자연", "animal_insect": "동물/곤충", "environment": "자연환경", "things": "사물", "vehicles": "이동수단", "others": "기타", "fantasy": "판타지", "instrument": "악기", "piano": "피아노", "marimba": "마림바", "drum": "드럼", "janggu": "장구", "sound_effect": "효과음", "others_instrument": "기타타악기", "aboutEntryDesc_1": "엔트리는 누구나 무료로 소프트웨어 교육을 받을 수 있게 개발된 소프트웨어 교육 플랫폼입니다.", "aboutEntryDesc_2": "학생들은 소프트웨어를 쉽고 재미있게 배울 수 있고,", "aboutEntryDesc_3": "선생님은 효과적으로 학생들을 가르치고 관리할 수 있습니다.", "aboutEntryDesc_4": "엔트리는 공공재와 같이", "aboutEntryDesc_5": "비영리로 운영됩니다.", "viewProjectTerms": "이용정책 보기", "openSourceTitle": "오픈소스를 통한 생태계 조성", "openSourceDesc_1": "엔트리의 소스코드 뿐 아니라", "openSourceDesc_2": "모든 교육 자료는 CC라이센스를 ", "openSourceDesc_3": "적용하여 공개합니다.", "viewOpenSource": "오픈소스 보기", "eduPlatformTitle": "국내교육 현장에 맞는 교육 플랫폼", "eduPlatformDesc_1": "국내 교육 현장에 적합한 교육 도구가", "eduPlatformDesc_2": "될 수 있도록 학교 선생님들과 함께", "eduPlatformDesc_3": "개발하고 있습니다.", "madeWith": "자문단", "researchTitle": "다양한 연구를 통한 전문성 강화", "researchDesc_1": "대학/학회 등과 함께 다양한 연구를", "researchDesc_2": "진행하여 전문성을 강화해나가고", "researchDesc_3": "있습니다.", "viewResearch": "연구자료 보기", "atEntry": "엔트리에서는", "entryLearnDesc_1": "재미있게 배우는 학습공간", "entryLearnDesc_2": "<학습하기>에서는 컴퓨터를 활용해 논리적으로 문제를 해결할 수 있는 다양한 학습", "entryLearnDesc_3": "콘텐츠가 준비되어 있습니다. 게임을 하듯이 재미있게 주어진 미션들을 프로그래밍으로", "entryLearnDesc_4": "해결해볼 수 있고 유익한 동영상을 통해 소프트웨어의 원리를 배울 수 있습니다.", "entryMakeDesc_1": "<만들기>에서는 미국 MIT에서 개발한 Scratch와 같은 블록형 프로그래밍 언어를", "entryMakeDesc_2": "사용하여 프로그래밍을 처음 접하는 사람들도 쉽게 자신만의 창작물을 만들 수 있습니다.", "entryMakeDesc_3": "또한 블록 코딩과 텍스트 코딩의 중간다리 역할을 하는 '엔트리파이선' 모드에서는", "entryMakeDesc_4": "텍스트 언어의 구조와 문법을 자연스럽게 익힐 수 있습니다.", "entryMakeDesc_5": "", "entryShareDesc_1": "<공유하기>에서는 엔트리를 통해 제작한 작품을 다른 사람들과 공유할 수 있습니다.", "entryShareDesc_2": "또한 공유된 작품이 어떻게 구성되었는지 살펴보고 발전시켜 자신만의 작품을 만들 수", "entryShareDesc_3": "있습니다. 공동 창작도 가능하여 친구들과 협업해 더 멋진 작품을 만들어 볼 수 있습니다.", "entryGroup": "학급기능", "entryGroupTitle": "우리 반 학습 공간", "entryGroupDesc_1": "<학급기능>은 선생님이 학급별로 학생들을 관리할 수 있는 기능입니다. 학급끼리 학습하고", "entryGroupDesc_2": "작품을 공유할 수 있으며 과제를 만들고 학생들의 결과물을 확인할 수 있습니다.", "entryGroupDesc_3": "또한 선생님은 강의 기능을 활용하여 학생들의 수준에 맞는 학습환경을", "entryGroupDesc_4": "맞춤형으로 제공함으로써 효율적이고 편리하게 수업을 진행할 수 있습니다.", "entryGroupDesc_5": "", "unpluggedToPhysical": "언플러그드 활동부터 피지컬 컴퓨팅까지", "algorithmActivity": "기초 알고리즘", "programmignLang": "교육용 프로그래밍 언어", "unpluggedDesc_1": "엔트리봇 보드게임과 카드게임을 통해 컴퓨터 없이도", "unpluggedDesc_2": "소프트웨어의 기본 개념과 원리(순차, 반복, 선택, 함수)를 익힐 수 있습니다.", "entryMaze": "엔트리봇 미로탈출", "entryAI": "엔트리봇 우주여행", "algorithmDesc_1": "게임을 하듯이 미션을 해결하고 인증서를 받아보세요.", "algorithmDesc_2": "소프트웨어의 기본적인 원리를 쉽고 재미있게 배울 수 있습니다.", "programmingLangDesc_1": "엔트리에서는 블록을 쌓듯이 프로그래밍을 하기 때문에 누구나 쉽게", "programmingLangDesc_2": "자신만의 게임, 애니메이션, 미디어아트와 같은 멋진 작품을 만들고 공유할 수 있어 교육용으로 적합합니다.", "viewSupporHw": "연결되는 하드웨어 보기", "supportHwDesc_1": "엔트리와 피지컬 컴퓨팅 도구를 연결하면 현실세계와 상호작용하는 멋진 작품들을 만들어낼 수 있습니다.", "supportHwDesc_2": "국내, 외 다양한 하드웨어 연결을 지원하며, 계속적으로 추가될 예정입니다.", "entryEduSupport": "엔트리 교육 지원", "eduSupportDesc_1": "엔트리에서는 소프트웨어 교육을 위한 다양한 교육 자료를 제작하여 무상으로 배포하고 있습니다.", "eduSupportDesc_2": "모든 자료는 교육자료 페이지에서 다운받으실 수 있습니다.", "materials_1_title": "수준별 교재", "materials_1_desc_1": "학년별 수준에 맞는 교재를 통해 차근차근", "materials_1_desc_2": "따라하며 쉽게 엔트리를 익혀보세요!", "materials_2_title": "EBS 방송 연계 교안", "materials_2_desc_1": "EBS 소프트웨어야 놀자 방송과 함께", "materials_2_desc_2": "교사용 수업 지도안을 제공합니다.", "materials_3_title": "초, 중등 교과 연계 수업자료", "materials_3_title_2": "", "materials_3_desc_1": "다양한 과목에서 만나는 실생활 문제를", "materials_3_desc_2": "컴퓨팅 사고력으로 해결해 보세요.", "moreMaterials": "더 많은 교육 자료 보러가기", "moreInfoAboutEntry_1": "더 많은 엔트리의 소식들을 확인하고 싶다면 아래의 링크들로 접속해보세요.", "moreInfoAboutEntry_2": "교육자료 외에도 다양한 SW 교육과 관련한 정보를 공유하고 있습니다.", "blog": "블로그", "post": "포스트", "tvCast": "TV캐스트", "albertSchool": "알버트 스쿨버전", "arduinoBoard": "아두이노 정품보드", "arduinoCompatible": "아두이노 호환보드", "bitBlock": "비트블록", "bitbrick": "비트브릭", "byrobot_dronefighter_controller": "바이로봇 드론파이터 조종기", "byrobot_dronefighter_drive": "바이로봇 드론파이터 자동차", "byrobot_dronefighter_flight": "바이로봇 드론파이터 드론", "byrobot_petrone_v2_controller": "바이로봇 페트론V2 조종기", "byrobot_petrone_v2_drive": "바이로봇 페트론V2 자동차", "byrobot_petrone_v2_flight": "바이로봇 페트론V2 드론", "trueRobot": "뚜루뚜루", "codeino": "코드이노", "e-sensor": "E-센서보드", "e-sensorUsb": "E-센서보드(유선연결)", "e-sensorBT": "E-센서보드(무선연결)", "mechatronics_4d": "4D 메카트로닉스", "hamster": "햄스터", "hummingbirdduo": "허밍버드 듀오", "roboid": "로보이드", "turtle": "거북이", "littlebits": "리틀비츠", "orangeBoard": "오렌지 보드", "robotis_carCont": "로보티즈 로봇자동차", "robotis_IoT": "로보티즈 IoT", "robotis_IoT_Wireless": "로보티즈 IoT(무선연결)", "dplay": "디플레이", "iboard": " 아이보드", "nemoino": "네모이노", "Xbot": "엑스봇(원터치 동글/USB)", "XbotBT": "엑스봇 에뽀/엣지 블투투스", "robotori": "로보토리", "rokoboard": "로코보드", "Neobot": "네오봇", "about": "알아보기", "articles": "토론하기", "gallery": "구경하기", "learn": "학습하기", "login": "로그인", "logout": "로그아웃", "make": "만들기", "register": "가입하기", "Join": "회원가입", "Edit_info": "내 정보 수정", "Discuss": "글 나누기", "Explore": "구경하기", "Load": "불러오기", "My_lesson": "오픈 강의", "Resources": "교육 자료", "play_software": "소프트웨어야 놀자!", "problem_solve": "엔트리 학습하기", "Learn": "학습하기", "teaching_tools": "엔트리 교구", "about_entry": "엔트리 소개", "what_entry": "엔트리는?", "create": "만들기", "create_new": "새로 만들기", "start_programming": "소프트웨어 교육의 첫걸음", "Entry": "엔트리", "intro_learning": "누구나 쉽고 재밌게 소프트웨어를 배울 수 있어요. ", "intro_learning_anyone": "지금 바로 시작해보세요! ", "start_now": "For Free, Forever.", "welcome_entry": "엔트리에 오신걸 환영합니다.", "student": "학생", "non_menber": "일반인", "teacher": "선생님", "terms_conditions": "이용약관", "personal_information": "개인정보 수집 및 이용에 대한 안내", "limitation_liability": "책임의 한계와 법적 고지", "entry_agree": "엔트리의 이용약관에 동의 합니다.", "info_agree": "개인정보 수집 및 이용에 동의합니다.", "next": "다음", "enter_id": "아이디 입력", "enter_password": "비밀번호 입력", "confirm_password": "비밀번호 확인", "enter_password_again": "비밀번호를 한번 더 입력하세요.", "validation_password": "5자 이상의 영문/숫자 등을 조합하세요.", "validation_id": "4~20자의 영문/숫자를 조합하세요", "prev": "이전", "born_year": "태어난 연도", "select_born": "태어난 연도를 선택 하세요", "year": "년", "gender": "성별", "choose_gender": "성별을 선택 하세요", "male": "남성", "female": "여성", "language": "언어", "best_language": "주 언어를 선택 하세요", "korean": "한국어", "english": "영어", "viet": "베트남", "option_email": "이메일(선택)", "insert_email": "이메일 주소를 입력 하세요", "sign_up_complete": "회원 가입이 완료 되었습니다", "agree_terms_conditions": "이용약관에 동의해 주세요.", "agree_personal_information": "개인정보 수집 및 이용에 대한 안내에 동의해 주세요.", "insert_studying_stage": "작품을 공유하고 싶은 학급을 선택해 주세요.", "insert_born_year": "태어난 연도를 입력해 주세요.", "insert_gender": "성별을 입력해 주세요.", "select_language": "언어를 선택해 주세요.", "check_email": "이메일 형식을 확인해 주세요.", "already_exist_id": "이미 존재하는 아이디 입니다.", "id_validation_id": "아이디는 4~20자의 영문/숫자를 조합하세요", "password_validate_pwd": "패스워드는 5자 이상의 영문/숫자 등을 조합하세요.", "insert_same_pwd": "같은 비밀번호를 입력해 주세요.", "studying_stage_group": "작품 공유 학급", "studying_stage": "작품을 공유하고 싶은 학급을 선택해 주세요.", "password": "비밀번호 입력", "save_id": "아이디 저장", "auto_login": "자동 로그인", "forgot_password": "아이디와 비밀번호가 기억나지 않으세요 ?", "did_not_join": "아직 엔트리 회원이 아니세요?", "go_join": "회원가입하기 ", "first_step": "소프트웨어 교육의 첫걸음", "entry_content_one": "상상했던 것들을 블록 놀이하듯 하나씩 쌓아보세요.", "entry_content_two": "게임, 애니메이션, 미디어아트와 같은 멋진 작품이 완성된답니다!", "entry_content_three": "재미있는 놀이로 배우고, 나만의 멋진 작품을 만들어 친구들과 공유할 수 있는 멋진 엔트리의 세상으로 여러분을 초대합니다!", "funny_space": "재미있게 배우는 학습공간", "in_learn_section": "< 학습하기 > 에서는", "learn_problem_solving": "컴퓨터를 활용해 논리적으로 문제를 해결할 수 있는 다양한 학습 콘텐츠가 준비되어 있습니다. 게임을 하듯이 주어진 미션들을 프로그래밍으로 해결해볼 수도 있고 재미있는 동영상으로 소프트웨어의 원리를 배울 수도 있습니다 .", "joy_create": "창작의 즐거움", "in_make": "< 만들기 > 는", "make_contents": "미국 MIT에서 개발한 Scratch와 같은 비주얼 프로그래밍 언어를 사용하여 프로그래밍을 처음 접하는 사람들도 쉽게 나만의 창작물을 만들 수 있습니다. 또 엔트리를 통해 만들 수 있는 컨텐츠의 모습은 무궁무진합니다. 과학 시간에 배운 물리 법칙을 실험해 볼 수도 있고 좋아하는 캐릭터로 애니메이션을 만들거나 직접 게임을 만들어 볼 수 있습니다.", "and_content": "또 엔트리를 통해 만들 수 있는 콘텐츠의 모습은 무궁무진합니다. 과학 시간에 배운 물리 법칙을 실험해 볼 수도 있고 좋아하는 캐릭터로 애니메이션을 만들거나 직접 게임을 만들어 볼 수 있습니다.", "share_collaborate": "공유와 협업", "explore_contents": "< 구경하기 > 에서는 엔트리를 통해 제작한 작품을 다른 사람들과 쉽게 공유할 수 있습니다. 또한 공유된 작품이 어떻게 구성되었는지 살펴볼 수 있고, 이를 발전시켜 자신만의 프로젝트를 만들 수 있습니다. 그리고 엔트리에서는 공동 창작도 가능합니다. 친구들과 협업하여 더 멋진 프로젝트를 만들어볼 수 있습니다.", "why_software": "왜 소프트웨어 교육이 필요할까?", "speak_obama_contents": "컴퓨터 과학을 배우는 것은 단지 여러분의 미래에만 중요한 일이 아닙니다. 이것은 우리 미국의 미래를 위해 중요한 일 입니다.", "obama": "버락 오바마", "us_president": "미국 대통령", "billgates_contents": "컴퓨터 프로그래밍은 사고의 범위를 넓혀주고 더 나은 생각을 할 수 있게 만들며 분야에 상관없이 모든 문제에 대해 새로운 해결책을 생각할 수 있는 힘을 길러줍니다.", "billgates": "빌게이츠", "chairman_micro": "Microsoft 회장", "eric_contents": "현재 디지털 혁명은 지구상 대부분의 사람들에게 아직 시작도 안된 수준입니다. 프로그래밍을 통해 향후 10년간 모든 것이 변화할 것 입니다.", "eric": "에릭 슈미츠", "sandbug_contents": "오늘날 컴퓨터 과학에 대한 이해는 필수가 되었습니다. 우리의 국가 경쟁력은 우리가 아이들에게 이것을 얼마나 잘 가르칠 수 있느냐에 달려있습니다.", "sandbug": "쉐릴 샌드버그", "view_entry_tools": "엔트리와 함께할 수 있는 교구들을 살펴볼 수 있습니다.", "solve_problem": "미션 해결하기", "solve_problem_content": "게임을 하듯 미션을 하나 하나 해결하며 소프트웨어의 기본 원리를 배워보세요!", "find_extra_title": "엔트리봇 부품 찾기 대작전", "all_ages": "전 연령", "total": "총", "step": "단계", "find_extra_contents": "로봇 강아지를 생산하던 루츠 공장에 어느 날 갑자기 일어난 정전 사태로 태어난 특별한 강아지 엔트리 봇. 아직 조립이 덜 된 나머지 부품들을 찾아 공장을 탈출 하도록 도와주면서 소프트웨어의 동작 원리를 익혀보자!", "software_play_contents": "EBS에서 방영한 '소프트웨어야 놀자' 프로그램을 실습해볼 수 있습니다.", "resources_contents": "엔트리를 활용한 다양한 교육자료들을 무료로 제공합니다.", "from": " 출처", "sw_camp": "미래부 SW 창의캠프", "elementary": "초등학교", "middle": "중학교", "grades": "학년", "lesson": "차시", "sw_contents_one": "5차시 분량으로 초등학생이 엔트리와 피지컬 컴퓨팅을 경험할 수 있는 교재입니다. 학생들은 엔트리 사용법을 학습하고, 그림판과 이야기 만들기를 합니다. 마지막에는 아두이노 교구를 활용하여 키보드를 만들어보는 활동을 합니다.", "sw_camp_detail": "미래창조과학부 SW창의캠프", "sw_contents_two": "5차시 분량으로 중학생이 엔트리와 피지컬 컴퓨팅을 경험할 수 있는 교재입니다. 학생들은 엔트리 사용법을 학습하고, 미로찾기 게임과, 퀴즈 프로그램을 만들어 봅니다. 마지막에는 아두이노 교구를 활용하여 키보드로 자동차를 조종하는 활동을 합니다.", "sw_contents_three": "선생님들이 학교에서 시작할 수 있는 소프트웨어 수업 지도서입니다. 다양한 언플러그드 활동과, '소프트웨어야 놀자' 방송을 활용한 수업 지도안이 담겨 있습니다.", "naver_sw": "NAVER 소프트웨어야 놀자", "teacher_teaching": "교사용지도서 (초등학교 5~6학년 이상)", "funny_sw": "즐거운 SW놀이 교실", "sw_contents_four": "소프트웨어를 놀이하듯 재미있게 배울 수 있는 교재로 엔트리보드게임을 비롯한 다양한 언플러그드 활동과 엔트리 학습모드로 소프트웨어를 만드는 기본 원리를 배우게 됩니다. 기본 원리를 배웠다면 학생들은 이제 엔트리로 이야기, 게임, 예술작품, 응용프로그램을 만드는 방법을 배우고, 자신이 생각한 소프트웨어를 만들고 발표할 수 있도록 교재가 구성되어 있습니다.", "ct_text_5": "교과서와 함께 키우는 컴퓨팅 사고력", "teacher_grade_5": "교원 (초등학교 5학년)", "ct_text_5_content": "실생활의 문제를 해결하자는 테마로 준비된 총 8개의 학습콘텐츠가 담긴 교사용 지도안입니다. 각 콘텐츠는 개정된 교육과정을 반영한 타교과와의 연계를 통해 다양한 문제를 만나고 해결해볼 수 있도록 설계되었습니다. 아이들이 컴퓨팅 사고력을 갖춘 융합형 인재가 될 수 있도록 지금 적용해보세요!", "ct_text_6": "교과서와 함께 키우는 컴퓨팅 사고력", "teacher_grade_6": "교원 (초등학교 6학년)", "ct_text_6_content": "실생활의 문제를 해결하자는 테마로 준비된 총 8개의 학습콘텐츠가 담긴 교사용 지도안입니다. 각 콘텐츠는 개정된 교육과정을 반영한 타교과와의 연계를 통해 다양한 문제를 만나고 해결해볼 수 있도록 설계되었습니다. 아이들이 컴퓨팅 사고력을 갖춘 융합형 인재가 될 수 있도록 지금 적용해보세요!", "sw_use": "모든 교재들은 비영리 목적에 한하여 저작자를 밝히고 자유롭게 이용할 수 있습니다.", "title": "제목", "writer": "작성자", "view": "보기", "date": "등록일", "find_id_pwd": "아이디와 비밀번호 찾기", "send_email": "이메일로 비밀번호 변경을 위한 링크를 발송해드립니다.", "user_not_exist": "존재하지 않는 이메일 주소 입니다.", "not_signup": "아직 회원이 아니세요?", "send": "발송하기", "sensorboard": "엔트리봇 센서보드", "physical_computing": "피지컬 컴퓨팅", "sensorboard_contents": "아두이노를 사용하기 위해서 더 이상 많은 케이블을 사용해 회로를 구성할 필요가 없습니다. 엔트리 보드는 아두이노 위에 끼우기만 하면 간단하게 LED, 온도센서, 소리센서, 빛, 슬라이더, 스위치를 활용할 수 있습니다. 이제 엔트리 보드를 활용해 누구라도 쉽게 자신만의 특별한 작품을 만들어보세요!", "entrybot_boardgame": "엔트리봇 보드게임", "unplugged": "언플러그드 활동", "unplugged_contents": "재밌는 보드게임을 통해 컴퓨터의 작동 원리를 배워보세요. 로봇강아지인 엔트리봇이 정전된 공장에서 필요한 부품을 찾아 탈출하도록 돕다보면 컴퓨터 전문가처럼 문제를 바라 볼 수 있게됩니다.", "entrybot_cardgame": "엔트리봇 카드게임 : 폭탄 대소동", "entrybot_cardgame_contents": "갑자기 엔트리도시에 나타난 12종류의 폭탄들! 과연 폭탄들을 안전하게 해체할 수 있을까요? 폭탄들을 하나씩 해체하며 엔트리 블록과 함께 소프트웨어의 원리를 배워봐요! 순차, 반복, 조건을 통해 폭탄을 하나씩 해체하다 보면 엔트리도시를 구한 영웅이 될 수 있답니다!", "basic_learn": "엔트리 기본 학습", "basic_learn_contents": "엔트리를 활용한 다양한 교육 콘텐츠를 제공합니다.", "troubleshooting": "문제해결 학습", "playsoftware": "소프트웨어야 놀자", "make_own_lesson": "나만의 수업을 만들어 다른 사람과 공유할 수 있습니다.", "group_lecture": "우리 반 강의", "group_curriculum": "우리 반 강의 모음", "group_homework": "우리 반 과제", "group_noproject": "전시된 작품이 없습니다.", "group_nolecture": "생성된 강의가 없습니다.", "group_nocurriculum": "생성된 강의 모음이 없습니다.", "lecture_contents": "필요한 기능만 선택하여 나만의 수업을 만들어 볼 수 있습니다.", "curriculum_contents": "여러개의 강의를 하나의 강의 모음으로 묶어 차근차근 따라할 수 있는 수업을 만들 수 있습니다.", "grade_info": "학년 정보", "difficulty": "난이도", "usage": "사용요소", "learning_concept": "학습개념", "related_subject": "연계 교과", "show_more": "더보기", "close": "닫기", "latest": "최신순", "viewCount": "조회수", "viewer": "조회순", "like": "좋아요순", "comment": "댓글순", "entire_period": "전체기간", "today": "오늘", "latest_week": "최근 1주일", "latest_month": "최근 1개월", "latest_three_month": "최근 3개월", "current_password": "현재 비밀번호", "change_password": "비밀번호 변경", "incorrect_password": "비밀번호가 일치하지 않습니다.", "blocked_user": "승인되지 않은 사용자 입니다.", "new_password": "새로운 비밀번호", "password_option_1": "영문과 숫자의 조합으로 5자 이상이 필요합니다.", "again_new_password": "새로운 비밀번호 재입력", "enter_new_pwd": "새로운 비밀번호를 입력하세요.", "confirm_new_pwd": "새로운 비밀번호를 확인하세요.", "enter_new_pwd_again": "새로운 비밀번호를 다시 입력하세요.", "password_match": "비밀번호가 일치하지 않습니다.", "incorrect_email": "유효한 이메일이 아닙니다", "edit_button": "정보수정", "edit_profile": "관리", "my_project": "나의 작품", "my_group": "나의 학급", "mark": "관심 작품", "prev_state": "이전", "profile_image": "자기소개 이미지", "insert_profile_image": "프로필 이미지를 등록해 주세요.", "at_least_180": "180 x 180 픽셀의 이미지를 권장합니다.", "upload_image": "이미지 업로드", "about_me": "자기소개", "save_change": "변경사항 저장", "basic_image": "기본 이미지", "profile_condition": "자기소개를 입력해 주세요. 50자 내외", "profile_back": "돌아가기", "make_project": "작품 만들기", "exhibit_project": "작품 전시하기", "art_list_shared": "개인", "art_list_group_shared": "학급", "view_project": "코드 보기", "noResult": "검색 결과가 없습니다.", "comment_view": "댓글", "upload_project": "올리기", "edit": "수정", "save_complete": "저장", "just_like": "좋아요", "share": "공유", "who_likes_project": "작품을 좋아하는 사람", "people_interest": "작품을 관심있어 하는 사람", "none_person": "없음", "inserted_date": "등록일", "last_modified": "최종 수정일", "original_project": "원본 작품", "for_someone": "님의", "original_project_deleted": "원본 작품이 삭제되었습니다.", "delete_project": "삭제", "delete_group_project": "목록에서 삭제", "currnet_month_time": "월", "current_day_time": "일", "game": "게임", "animation": "애니메이션", "media_art": "미디어 아트", "physical": "피지컬", "etc": "기타", "connected_contents": "연계되는 콘텐츠", "connected_contents_content": "엔트리와 함께 할 수 있는 다양한 콘텐츠를 만나보세요. 처음 소프트웨어를 배우는 사람이라면 쉽게 즐기는 보드게임부터 아두이노와 같은 피지컬 컴퓨팅을 활용하여 자신만의 고급스러운 창작물을 만들어 볼 수 있습니다.", "basic_mission": "기본 미션: 엔트리봇 미로찾기", "basic_mission_content": "강아지 로봇을 만드는 공장에서 우연한 정전으로 혼자서 생각할 수 있게 된 엔트리봇! 공장을 탈출하고 자유를 찾을 수 있도록 엔트리봇을 도와주세요!", "application_mission": "응용미션: 엔트리봇 우주여행", "write_article": "글쓰기", "view_all_articles": "모든 글 보기", "view_own_articles": "내가 쓴 글 보기", "learning_materials": "교육자료", "ebs_software_first": "<소프트웨어야 놀자>는 네이버와 EBS가 함께 만든 교육 콘텐츠입니다. 여기에서는 엔트리를 활용하여 실제로 간단한 프로그램을 만들어보며 소프트웨어의 기초 원리를 배워나갈 수 있습니다. 또한 각 콘텐츠에서는 동영상을 통해 컴퓨터과학에 대한 선행지식이 없더라도 충분히 재미와 호기심을 느끼며 진행할 수 있도록 준비되어있습니다.", "go_software": "소프트웨어야 놀자 가기", "ebs_context": "EBS 동영상 가기", "ebs_context_hello": "EBS 가기", "category": "카테고리", "add_picture": "사진첨부", "upload_article": "글 올리기", "list": "목록", "report": "신고하기", "upload": "올리기", "staff_picks": "스태프 선정", "popular_picks": "인기 작품", "lecture_header_more": "더 만들어 보기", "lecture_header_reset": "초기화", "lecture_header_reset_exec": "초기화 하기", "lecture_header_save": "저장", "lecture_header_save_content": "학습내용 저장하기", "lecture_header_export_project": "내 작품으로 저장하기", "lecture_header_undo": "취소", "lecture_header_redo": "복원", "lecture_er_bugs": "버그신고", "lecture_container_tab_object": "오브젝트", "lecture_container_tab_video": "강의 동영상", "lecture_container_tab_project": "완성된 작품", "lecture_container_tab_help": "블록 도움말", "illigal": "불법적인 내용 또는 사회질서를 위반하는 활동", "verbal": "언어 폭력 또는 개인 정보를 침해하는 활동", "commertial": "상업적인 목적을 가지고 활동", "explicit": "음란물", "other": "기타", "check_one_more": "하나이상 표기해주세요.", "enter_content": "기타의 내용을 입력해 주세요.", "report_result": "결과 회신을 원하시면 메일을 입력해 주세요.", "report_success": "신고하기가 정상적으로 처리 되었습니다.", "etc_detail": "기타 항목 선택후 입력해주세요.", "lecture_play": "강의 보기", "list_view_link": "다른 강의 모음 보기", "lecture_intro": "강의 소개 보기", "study_goal": "학습목표", "study_description": "설명", "study_created": "등록일", "study_last_updated": "최종 수정일", "study_remove": "삭제", "study_group_lecture_remove": "목록에서 삭제", "study_group_curriculum_remove": "목록에서 삭제", "study_edit": "강의 모음 수정", "study_comments": "댓글", "study_comment_post": "올리기", "study_comment_remove": "삭제", "study_comment_edit": "수정", "study_comment_save": "저장", "study_guide_video": "안내 영상", "study_basic_project": "기본 작품", "study_done_project": "완성 작품을 선택하세요.", "study_usage_element": "사용요소", "study_concept_element": "적용개념", "study_subject_element": "연계교과", "study_computing_element": "컴퓨팅요소", "study_element_none": "없음", "study_label_like": "좋아요", "study_label_interest": "관심 강의", "study_label_share": "공유", "study_label_like_people": "강좌를 좋아하는 사람", "study_label_interest_people": "강좌를 관심있어 하는 사람", "study_related_lectures": "강의 목록", "study_expand": "전체보기", "study_collapse": "줄이기", "aftercopy": "주소가 복사되었습니다.", "study_remove_curriculum": "강의 모음을 삭제하시겠습니까?", "content_required": "내용을 입력하세요", "study_remove_lecture": "강의를 삭제하시겠습니까?", "lecture_build": "강의 만들기", "lecture_build_step1": "1. 강의를 소개하기 위한 정보를 입력해주세요", "lecture_build_step2": "2. 학습에 사용되는 기능들만 선택해주세요", "lecture_build_step3": "3. 모든 정보를 올바르게 입력했는지 확인해주세요", "lecture_build_choice": "어떤 것을 올리시겠습니까?", "lecture_build_project": "엔트리 작품", "lecture_build_video": "강의 영상", "lecture_build_grade": "추천학년", "lecture_build_goals": "학습목표", "lecture_build_add_goal": "이곳을 클릭하여 목표를 추가", "lecture_build_attach": "파일 첨부", "lecture_build_attach_text": "20MB 이내의 파일을 업로드해 주세요.", "lecture_build_assist": "보조 영상", "lecture_build_youtube_url": "Youtube 공유 링크를 넣어주세요.", "lecture_build_project_done": "완성 작품을 선택하세요.", "lecture_build_scene_text1": "장면기능을 끄면 새로운 장면을 추가하거나,", "lecture_build_scene_text2": "삭제할 수 없습니다.", "lecture_build_object_text": "오브젝트 추가하기를 끄면 새로운 오브젝트를 추가하거나 삭제할 수 없습니다.", "lecture_build_blocks_text1": "학습에 필요한 블록들만 선택해주세요.", "lecture_build_blocks_text2": "선택하지 않은 블록은 숨겨집니다.", "lecture_build_basic1": "학습을 시작할때 사용할 작품을 선택해 주세요.", "lecture_build_basic2": "학습자는 선택한 작품을 가지고 학습을 하게 됩니다.", "lecture_build_help": "이 도움말을 다시 보시려면 눌러주세요.", "lecture_build_help_never": "다시보지 않기", "lecture_build_close": "닫기", "lecture_build_scene": "장면 1", "lecture_build_add_object": "오브젝트 추가하기", "lecture_build_start": "시작하기", "lecture_build_tab_code": "블록", "lecture_build_tab_shape": "모양", "lecture_build_tab_sound": "소리", "lecture_build_tab_attribute": "속성", "lecture_build_block_category": "블록 카테고리를 선택하세요.", "lecture_build_attr_all": "전체", "lecture_build_attr_var": "변수", "lecture_build_attr_signal": "신호", "lecture_build_attr_list": "리스트", "lecture_build_attr_func": "함수", "lecture_build_edit": "강의 수정", "lecture_build_remove": "삭제", "curriculum_build": "강의 모음 만들기", "curriculum_step1": "1. 강의 모음을 소개하는 정보를 입력해주세요.", "curriculum_step2": "2. 강의 모음을 구성하는 강의를 선택해주세요.", "curriculum_step3": "3. 올바르게 강의 모음이 구성되었는지 확인해주세요.", "curriculum_lecture_upload": "강의 올리기", "curriculum_lecture_edit": "강의 편집", "curriculum_lecture_open": "불러오기", "group_lecture_add": "우리 반 강의 추가하기", "group_curriculum_add": "우리 반 강의 모음 추가하기", "group_lecture_delete": "삭제", "group_curriculum_delete": "삭제", "group_select": "", "group_studentNo": "학번", "group_username": "이름", "group_userId": "아이디", "group_tempPassword": "비밀번호 수정", "group_gender": "성별", "group_studentCode": "코드", "group_viewWorks": "작품 보기", "added_group_lecture": "강의가 삭되었습니다.", "added_group_curriculum": "강의 모음이 삭제되었습니다.", "deleted_group_lecture": "강의가 삭제되었습니다.", "deleted_group_curriculum": "강의 모음이 삭제되었습니다.", "modal_my": "나의", "modal_interest": "관심", "modal_project": "작품", "section": "단원", "connect_hw": "하드웨어 연결", "connect_message": "%1에 연결되었습니다.", "connect_fail": "하드웨어 연결에 실패했습니다. 연결프로그램이 켜져 있는지 확인해 주세요.", "interest_curriculum": "관심 강의 모음", "marked_curriculum": "관심 강의 모음", "searchword_required": "검색어를 입력하세요.", "file_required": "파일은 필수 입력 항목입니다.", "file_name_error": "올바른 파일이름을 입력해 주세요.", "file_upload_max_count": "한번에 10개까지 업로드가 가능합니다.", "image_file_only": "이미지 파일만 등록이 가능합니다.", "file_upload_max_size": "10MB 이하만 업로드가 가능합니다.", "curriculum_modal_lectures": "나의 강의", "curriculum_modal_interest": "관심 강의", "group_curriculum_modal_curriculums": "나의 강의 모음", "group_curriculum_modal_interest": "관심 강의 모음", "picture_import": "모양 가져오기", "picture_select": "모양 선택", "lecture_list_view": "다른 강의보기", "play_software_2": "EBS 소프트웨어야 놀자2", "play_software_2_content": "네이버와 EBS가 함께 만든 두 번째 이야기, <소프트웨어야 놀자> 시즌2를 만나보세요! 재미있는 동영상 강의를 통해 소프트웨어의 기본 개념을 배워보고, 다양하고 흥미로운 주제로 실생활 문제를 해결해 볼 수 있습니다. 방송영상과 특별영상을 보며 재미있는 프로그램들을 직접 만들어보세요. 소프트웨어 교육을 처음 접하는 친구들도 쉽게 소프트웨어와 친구가 될 수 있답니다!", "open_project_to_all": "공개", "close_project": "비공개", "category_media_art": "미디어 아트", "go_further": "더 나아가기", "marked_project": "관심 작품", "marked_group_project": "학급 관심 작품", "basic": "기본", "application": "응용", "the_great_escape": "탈출 모험기", "escape_guide_1": "강아지 로봇을 만드는 공장에서 우연한 정전으로 혼자서 생각할 수 있게 된 엔트리봇! ", "escape_guide_1_2": " 공장을 탈출하고 자유를 찾을 수 있도록 엔트리봇을 도와주세요!", "escape_guide_2": "엔트리봇이 먼 길을 가기엔 고쳐야 할 곳이 너무 많아 공장에서 탈출하면서 몸을 수리할 수 있는 부품들을 찾아보자! 아직 몸이 완전하지는 않지만 걷거나 뛰면서, 방향을 바꾸는 정도는 가능할 거야! ", "escape_guide_2_2": "학습 목표: 순차적 실행", "escape_guide_3": "드디어 공장을 탈출했어! 하지만 마을로 가기 위해서는 아직 가야 할 길이 멀어. 그래도 몸은 어느 정도 고쳐져서 똑같은 일을 많이 해도 무리는 없을 거야! 어? 근데 저 로봇은 뭐지? ", "escape_guide_3_2": "학습 목표: 반복문과 조건문", "escape_guide_4": "드디어 마을 근처까지 왔어! 아까부터 똑같은 일을 많이 했더니 이제 외울 지경이야! 차라리 쓰일 블록은 이제 기억해뒀다가 쓰면 좋을 것 같아. 여기서 배터리만 충전해 놓으면 이제 평생 자유롭게 살 수 있을 거야.", "escape_guide_4_2": "학습 목표: 함수 정의와 호출", "space_travel_log": "우주 여행기", "space_guide_1": "머나먼 우주를 탐사하기 위해 떠난 엔트리봇. 드디어 탐사 임무를 마치고 고향별인 지구로 돌아오려 하는데 수많은 돌이 지구로 가는 길을 막고 있다! 엔트리봇이 안전하게 지구로 돌아올 수 있도록 도와주세요!", "space_guide_2": "드디어 지구에 돌아갈 시간이야! 얼른 지구에 돌아가서 쉬고 싶어!앞에 돌들이 어떻게 되어 있는지 확인하고 언제 어디로 가야 하는지 알려줘! 그러면 내가 가르쳐준 방향으로 움직일게!", "space_guide_2_2": "학습 목표: 조건문 중첩과 논리 연산", "cfest_mission": "엔트리 체험 미션", "maze_1_intro": "안녕 나는 엔트리봇이라고 해. 지금 나는 다친 친구들을 구하려고 하는데 너의 도움이 필요해. 나를 도와서 친구들을 구해줘! 먼저 앞으로 가기 블록을 조립하고 시작을 눌러봐", "maze_1_title": "시작 방법", "maze_1_content": "엔트리봇은 어떻게 움직이나요?", "maze_1_detail": "1. 블록 꾸러미에서 원하는 블록을 꺼내어 “시작하기를 클릭했을 때” 블록과 연결해봐 <br> 2. 다 조립했으면, 시작을 눌러봐 <br> 3. 나는 네가 조립한 블록대로 위에서부터 순서대로 움직일게", "maze_2_intro": "좋아! 덕분에 첫 번째 친구를 무사히 구할 수 있었어! 그럼 다음 친구를 구해볼까? 어! 그런데 앞에 벌집이 있어! 뛰어넘기 블록을 사용해서 벌집을 피하고 친구를 구해보자.", "maze_2_title_1": "장애물 뛰어넘기", "maze_2_content_1": "장애물이 있으면 어떻게 해야하나요?", "maze_2_detail_1": "길을 가다보면 장애물을 만날 수 있어. <br> 장애물이 앞에 있을 때에는 뛰어넘기 블록을 사용해야 해.", "maze_2_title_2": "시작 방법", "maze_2_content_2": "엔트리봇은 어떻게 움직이나요?", "maze_2_detail_2": "1. 블록 꾸러미에서 원하는 블록을 꺼내어 “시작하기를 클릭했을 때” 블록과 연결해봐 <br> 2. 다 조립했으면, 시작을 눌러봐 <br> 3. 나는 네가 조립한 블록대로 위에서부터 순서대로 움직일게", "maze_3_intro": "멋졌어! 이제 또 다른 친구를 구하러 가자~ 이번에는 아까 구한 친구가 준 반복하기 블록을 이용해볼까? 반복하기를 이용하면 똑같은 동작을 쉽게 여러번 할 수 있어! 한 번 반복할 숫자를 바꿔볼래?", "maze_3_title": "반복 블록(1)", "maze_3_content": "(3)회 반복하기 블록은 어떻게 사용하나요?", "maze_3_detail": "같은 행동을 여러번 반복하려면 ~번 반복하기 블록을 사용해야 해. <br> 반복하고 싶은 블록들을 ~번 반복하기 안에 넣고 반복 횟수를 입력하면 돼", "maze_4_intro": "훌륭해! 이제 구해야 할 친구 로봇들도 별로 남지 않았어. 벌집에 닿지 않도록 뛰어넘기를 반복하면서 친구에게 갈 수 있게 해줘!", "maze_4_title": "반복 블록(1)", "maze_4_content": "(3)회 반복하기 블록은 어떻게 사용하나요?", "maze_4_detail": "같은 행동을 여러번 반복하려면 ~번 반복하기 블록을 사용해야 해. <br> 반복하고 싶은 블록들을 ~번 반복하기 안에 넣고 반복 횟수를 입력하면 돼", "maze_5_intro": "대단해! 이제 반복하기 블록과 만약 블록을 같이 사용해보자~ 만약 블록을 사용하면 앞에 벽이 있을 때 벽이 없는 쪽으로 회전할 수 있어. 그럼 친구를 구해주러 출발해볼까?", "maze_5_title_1": "만약 블록", "maze_5_content_1": "만약 ~라면 블록은 어떻게 동작하나요?", "maze_5_detail_1": "만약 앞에 {이미지}가 있다면' 블록을 사용하면 앞에 {이미지}가 있을 때 어떤 행동을 할 지 정해줄 수 있어. <br> 앞에 {이미지}가 있을 때에만 블록 안의 블록들을 실행하고 <br> 그렇지 않으면 실행하지 않게 되는 거야.", "maze_5_title_2": "반복 블록(2)", "maze_5_content_2": "~를 만날 때 까지 반복하기 블록은 어떻게 사용하나요?", "maze_5_detail_2": "~까지 반복하기'를 사용하면 같은 행동을 언제까지 반복할지를 정해줄 수 있어. <br> 반복하고 싶은 블록들을 ~까지 반복하기안에 넣으면 돼. <br> 그러면 {이미지}와 같은 타일 위에 있는 경우 반복이 멈추게 될 거야.", "maze_6_intro": "이제 마지막 친구야! 아까 해본 것처럼만 하면 될거야! 그럼 마지막 친구를 구하러 가볼까?", "maze_6_title_1": "만약 블록", "maze_6_content_1": "만약 ~라면 블록은 어떻게 동작하나요?", "maze_6_detail_1": "만약 앞에 {이미지}가 있다면' 블록을 사용하면 앞에 {이미지}가 있을 때 어떤 행동을 할 지 정해줄 수 있어. <br> 앞에 {이미지}가 있을 때에만 블록 안의 블록들을 실행하고 <br> 그렇지 않으면 실행하지 않게 되는 거야.", "maze_6_title_2": "반복 블록(2)", "maze_6_content_2": "~를 만날 때 까지 반복하기 블록은 어떻게 사용하나요?", "maze_6_detail_2": "~까지 반복하기'를 사용하면 같은 행동을 언제까지 반복할지를 정해줄 수 있어. <br> 반복하고 싶은 블록들을 ~까지 반복하기안에 넣으면 돼. <br> 그러면 {이미지}와 같은 타일 위에 있는 경우 반복이 멈추게 될 거야.", "maze_programing_mode_0": "블록 코딩", "maze_programing_mode_1": "자바스크립트", "maze_operation1_title": "1단계 – 자바스크립트모드 안내", "maze_operation1_1_desc": "나는 로봇강아지 엔트리봇이야. 나에게 명령을 내려서 미션을 해결할 수 있게 도와줘! 미션은 시작할 때마다 <span class=\"textShadow\">\'목표\'</span>를 통해서 확인할 수 있어!", "maze_operation1_2_desc": "미션을 확인했다면 <b>명령</b>을 내려야 해 <span class=\"textUnderline\">\'명령어 꾸러미\'</span>는 <b>명령어</b>가 있는 공간이야. <b>마우스</b>와 <b>키보드</b>로 <b>명령</b>을 내릴 수 있어. <span class=\"textShadow\">마우스</span>로는 명령어 꾸러미에 있는 <b>명령어</b>를 클릭하거나, <b>명령어</b>를 <span class=\"textUnderline\">\'명령어 조립소\'</span>로 끌고와서 나에게 <b>명령</b>을 내릴 수 있어!", "maze_operation1_2_textset_1": "마우스로 명령어를 클릭하는 방법 ", "maze_operation1_2_textset_2": "마우스로 명령어를 드래그앤드랍하는 방법 ", "maze_operation1_3_desc": "<span class=\"textShadow\">키보드</span>로 명령을 내리려면 \'명령어 꾸러미\' 에 있는 <b>명령어를 키보드로 직접 입력하면 돼.</b></br> 명령어를 입력할 때 명령어 끝에 있는 <span class=\"textShadow\">()와 ;</span> 를 빼먹지 않도록 주의해야해!", "maze_operation1_4_desc": "미션을 해결하기 위한 명령어를 다 입력했다면 <span class=\"textShadow\">[시작하기]</span>를 누르면 돼.</br> [시작하기]를 누르면 나는 명령을 내린대로 움직일 거야!</br> 각 명령어가 궁금하다면 <span class=\"textShadow\">[명령어 도움말]</span>을 확인해봐!", "maze_operation7_title": "7단계 - 반복 명령 알아보기(횟수반복)", "maze_operation7_1_desc": "<b>똑같은 일</b>을 반복해서 명령하는건 매우 귀찮은 일이야.</br>이럴땐 <span class=\"textShadow\">반복</span>과 관련된 명령어를 사용하면 훨씬 쉽게 명령을 내릴 수 있어.", "maze_operation7_2_desc": "그렇다면 반복되는 명령을 쉽게 내리는 방법을 알아보자.</br>먼저 반복하기 명령어를 클릭한 다음, <span class=\"textShadow\">i<1</span> 의 숫자를 바꿔서 <span class=\"textShadow\">반복횟수</span>를 정하고</br><span class=\"textShadow\">괄호({ })</span> 사이에 반복할 명령어를 넣어주면 돼!", "maze_operation7_3_desc": "예를 들어 이 명령어<span class=\"textBadge number1\"></span>은 move(); 를 10번 반복해서 실행해.</br><span class=\"textBadge number2\"></span>명령어와 동일한 명령어지.", "maze_operation7_4_desc": "이 명령어를 사용할 때는 <span class=\"textShadow\">{ } 안에 반복할 명령어</span>를 잘 입력했는지,</br><span class=\"textShadow\">`;`</span>는 빠지지 않았는지 잘 살펴봐!</br>이 명령어에 대한 자세한 설명은 [명령어 도움말]에서 볼 수 있어.", "maze_operation7_1_textset_1": "똑같은 명령어를 반복해서 사용하는 경우", "maze_operation7_1_textset_2": "반복 명령어를 사용하는 경우", "maze_operation7_2_textset_1": "반복 횟수", "maze_operation7_2_textset_2": "반복할 명령", "maze_operation7_4_textset_1": "괄호({})가 빠진 경우", "maze_operation7_4_textset_2": "세미콜론(;)이 빠진 경우", "study_maze_operation8_title": "8단계 - 반복 명령 알아보기(횟수반복)", "study_maze_operation16_title": "4단계 - 반복 명령 알아보기(조건반복)", "study_maze_operation1_title": "1단계 - 반복 명령 알아보기(횟수반복)", "maze_operation9_title": "9단계 - 반복 명령 알아보기(조건반복)", "maze_operation9_1_desc": "앞에서는 몇 번을 반복하는 횟수반복 명령어에 대해 배웠어.</br>이번에는 <span class=\"textShadow\">계속해서 반복하는 명령어</span>를 살펴보자.</br>이 명령어를 사용하면 미션이 끝날 때까지 <b>동일한 행동</b>을 계속 반복하게 돼.</br>이 명령어 역시 괄호({ }) 사이에 반복할 명령어를 넣어 사용할 수 있어!", "maze_operation9_2_desc": "예를 들어 이 명령어 <span class=\"textBadge number1\"></span>은 미션을 완료할때까지 반복해서 move(); right()를 실행해.</br><span class=\"textBadge number2\"></span>명령어와 동일한 명령어지.", "maze_operation9_3_desc": "이 명령어를 사용할 때도 <span class=\"textShadow\">{ } 안에 반복할 명령어</span>를 잘 입력했는지,</br><span class=\"textShadow\">`true`</span>가 빠지지 않았는지 잘 살펴봐!</br>이 명령어에 대한 자세한 설명은 [명령어 도움말]에서 볼 수 있어.", "maze_operation9_1_textset_1": "반복할 명령", "maze_operation9_3_textset_1": "괄호({})가 빠진 경우", "maze_operation9_3_textset_2": "세미콜론(;)이 빠진 경우", "maze_operation9_3_textset_3": "true가 빠진 경우", "study_maze_operation3_title": "3단계 - 반복 명령 알아보기(조건반복)", "study_maze_operation4_title": "4단계 - 조건 명령 알아보기", "study_ai_operation4_title": "4단계 - 조건 명령과 레이더 알아보기", "study_ai_operation6_title": "6단계 - 중첩조건문 알아보기", "study_ai_operation7_title": "7단계 - 다양한 비교연산 알아보기", "study_ai_operation8_title": "8단계 - 물체 레이더 알아보기", "study_ai_operation9_title": "9단계 - 아이템 사용하기", "maze_operation10_title": "10단계 - 조건 명령 알아보기", "maze_operation10_1_desc": "앞에서는 미션이 끝날 때까지 계속 반복하는 반복 명령어에 대해 배웠어.</br>이번에는 특정한 조건에서만 행동을 하는 <span class=\"textShadow\">조건 명령어</span>를 살펴보자.</br><span class=\"textBadge number2\"></span>에서 보는것처럼 조건 명령어를 사용하면 <b>명령을 보다 효율적으로 잘 내릴 수 있어.</b>", "maze_operation10_2_desc": "조건 명령어는 크게 <span class=\"textShadow\">`조건`</span> 과 <span class=\"textShadow\">`조건이 발생했을때 실행되는 명령`</span>으로 나눌수 있어.</br>먼저 <span class=\"textUnderline\">조건</span> 부분을 살펴보자. If 다음에 나오는 <span class=\"textUnderline\">( ) 부분</span>이 조건을 입력하는 부분이야.</br><span class=\"textBadge number1\"></span>과 같은 명령어를 예로 살펴보자. <span class=\"textUnderline\">if(front == \“wall\”)</span> 는 만약 내 앞에(front) \"wall(벽)\"이 있다면을 뜻해", "maze_operation10_3_desc": "이제 <span class=\"textUnderline\">`조건이 발생했을 때 실행되는 명령`</span>을 살펴보자.</br>이 부분은 <span class=\"textShadow\">괄호{}</span>로 묶여 있고, 조건이 발생했을때 괄호안의 명령을 실행하게 돼!</br>조건이 발생하지 않으면 이 부분은 무시하고 그냥 넘어가게 되지.</br><span class=\"textBadge number1\"></span>의 명령어를 예로 살펴보자. 조건은 만약에 `내 앞에 벽이 있을 때` 이고,</br><b>이 조건이 발생했을 때 나는 괄호안의 명령어 right(); 처럼 오른쪽으로 회전하게 돼!</b>", "maze_operation10_4_desc": "<span class=\"textShadow\">조건 명령어</span>는 <span class=\"textShadow\">반복하기 명령어</span>와 함께 쓰이는 경우가 많아.</br>앞으로 쭉 가다가, 벽을 만났을때만 회전하게 하려면</br><span class=\"textUnderline pdb5\"><span class=\"textBadge number1\"></span><span class=\"textBadge number2\"></span><span class=\"textBadge number3\"></span>순서</span>와 같이 명령을 내릴 수 있지!", "maze_operation10_1_textset_1": "<b>[일반명령]</b>", "maze_operation10_1_textset_2": "<span class=\"textMultiline\">앞으로 2칸 가고</br>오른쪽으로 회전하고,</br>앞으로 3칸가고,</br>오른쪽으로 회전하고, 앞으로...</span>", "maze_operation10_1_textset_3": "<b>[조건명령]</b>", "maze_operation10_1_textset_4": "<span class=\"textMultiline\">앞으로 계속 가다가</br><span class=\"textEmphasis\">`만약에 벽을 만나면`</span></br>오른쪽으로 회전해~!</span>", "maze_operation10_2_textset_1": "조건", "maze_operation10_2_textset_2": "조건이 발생했을 때 실행되는 명령", "maze_operation10_3_textset_1": "조건", "maze_operation10_3_textset_2": "조건이 발생했을 때 실행되는 명령", "maze_operation10_4_textset_1": "<span class=\"textMultiline\">미션이 끝날때 까지</br>계속 앞으로 간다.</span>", "maze_operation10_4_textset_2": "<span class=\"textMultiline\">계속 앞으로 가다가,</br>만약에 벽을 만나면</span>", "maze_operation10_4_textset_3": "<span class=\"textMultiline\">계속 앞으로 가다가,</br>만약에 벽을 만나면</br>오른쪽으로 회전한다.</span>", "study_maze_operation18_title": "6단계 - 조건 명령 알아보기", "maze_operation15_title": "15단계 - 함수 명령 알아보기", "maze_operation15_1_desc": "자주 사용하는 명령어들을 매번 입력하는건 매우 귀찮은 일이야.</br>자주 사용하는 <span class=\"textUnderline\">명령어들을 묶어서 이름</span>을 붙이고,</br><b>필요할 때마다 그 명령어 묶음을 불러온다면 훨씬 편리하게 명령을 내릴 수 있어!</b></br>이런 명령어 묶음을 <span class=\"textShadow\">`함수`</span>라고 해. 이제 함수 명령에 대해 자세히 알아보자.", "maze_operation15_2_desc": "함수 명령어는 명령어를 묶는 <b>`함수만들기` 과정</b>과,</br>묶은 명령어를 필요할 때 사용하는 <b>`함수 불러오기` 과정</b>이 있어.</br>먼저 함수만들기 과정을 살펴보자.</br>함수를 만들려면 함수의 이름과, 그 함수에 들어갈 명령어를 입력해야 해.</br><span class=\"textShadow\">function</span>을 입력한 다음 <span class=\"textShadow\">함수의 이름</span>을 정할 수 있어. 여기서는 <span class=\"textShadow\">promise</span>로 만들거야.</br>함수 이름을 만들었으면 <span class=\"textUnderline\">()</span>를 붙여줘. 그 다음 <span class=\"textUnderline\">괄호({})</span>를 입력해.</br>그리고 <span class=\"textUnderline\">이 괄호 안에 함수에 들어갈 명령어들을 입력하면</span> 함수가 만들어져!", "maze_operation15_3_desc": "이 명령어를 예로 살펴보자. 나는 <span class=\"textShadow\">promise</span> 라는 함수를 만들었어.</br>이 함수를 불러서 실행하면 <span class=\"textUnderline\">괄호({})</span>안에 있는</br>move();</br>move();</br>left(); 가 실행돼!", "maze_operation15_4_desc": "함수를 불러와서 실행하려면 아까 만든 <b>함수의 이름을 입력하고 뒤에 `();`를 붙이면 돼.</b></br>promise 라는 이름으로 함수를 만들었으니 <span class=\"textShadow\">promise();</span> 를 입력하면 앞에서 묶어놓은</br>명령어들이 실행되는거지!</br><span class=\"number1 textBadge\"></span>과 같이 명령을 내리면 <span class=\"number2 textBadge\"></span>처럼 동작하게 돼!</br>함수 명령어를 사용하려면 <span class=\"number1 textBadge\"></span>과 같이 함수를 만들고 함수를 불러와야해!", "maze_operation15_1_textset_1": "자주 사용하는 명령어 확인하기", "maze_operation15_1_textset_2": "명령어들을 묶어서 이름 붙이기", "maze_operation15_1_textset_3": "명령어 묶음 불러오기", "maze_operation15_2_textset_1": "명령어 묶음의 이름(함수 이름)", "maze_operation15_2_textset_2": "묶을 명령어들", "maze_operation15_3_textset_1": "명령어 묶음의 이름(함수 이름)", "maze_operation15_3_textset_2": "묶을 명령어들", "maze_operation15_4_textset_1": "함수 만들기", "maze_operation15_4_textset_2": "함수 불러오기", "maze_operation15_4_textset_3": "실제 상황", "maze_object_title": "오브젝트 정보", "maze_object_parts_box": "부품 상자", "maze_object_trap": "함정", "maze_object_monster": "몬스터", "maze_object_obstacle1": "장애물", "maze_object_obstacle2": "bee", "maze_object_obstacle3": "banana", "maze_object_friend": "친구", "maze_object_wall1": "wall", "maze_object_wall2": "wall", "maze_object_wall3": "wall", "maze_object_battery": "베터리", "maze_command_ex": "예시", "maze_command_title": "명령어 도움말", "maze_command_move_desc": "엔트리봇을 한 칸 앞으로 이동시킵니다.", "maze_command_jump_desc": "아래 이미지와 같은 장애물 앞에서 장애물을 뛰어 넘습니다.</br><div class=\"obstacleSet\"></div>", "maze_command_jump_desc_elec": "아래 이미지와 같은 장애물 앞에서 장애물을 뛰어 넘습니다.</br><div class=\"obstacle_elec\"></div>", "maze_command_right_desc": "제자리에서 오른쪽으로 90도 회전합니다.", "maze_command_left_desc": "제자리에서 왼쪽으로 90도 회전합니다.", "maze_command_for_desc": "괄호<span class=\"textShadow\">{}</span> 안에 있는 명령을 <span class=\"textShadow\">입력한 횟수</span> 만큼 반복해서 실행합니다.", "maze_command_while_desc": "미션이 끝날 때가지 괄호<span class=\"textShadow\">{}</span> 안에 있는 명령을 계속 반복해서 실행합니다.", "maze_command_slow_desc": "아래 이미지와 같은 방지턱을 넘습니다.</br><div class=\"hump\"></div>", "maze_command_if1_desc": "조건 <span class=\"textShadow\">`바로 앞에 벽이 있을때`</span>이 발생했을 때,</br>괄호<span class=\"textShadow\">{}</span> 안에 있는 명령을 실행합니다.", "maze_command_if2_desc": "조건 <span class=\"textShadow\">`바로 앞에 벌집이 있을때`</span>이 발생했을 때,</br>괄호<span class=\"textShadow\">{}</span> 안에 있는 명령을 실행합니다.", "maze_command_if3_desc": "조건 <span class=\"textShadow\">`바로 앞에 바나나가 있을때`</span>이 발생했을 때,</br>괄호<span class=\"textShadow\">{}</span> 안에 있는 명령을 실행합니다.", "maze_command_promise_desc": "promise 라는 <span class=\"textShadow\">함수</span>를 만들고 실행하면 괄호<span class=\"textShadow\">{}</span> 안에</br>있던 명령어가 실행합니다.", "perfect": "아주 완벽해! ", "succeeded_using_blocks": " 개의 블록을 사용해서 성공했어!", "succeeded_using_commands": " 개의 명령어를 사용해서 성공했어!", "awesome": "대단한 걸!", "succeeded_go_to_next": "개의 블록만으로 성공했어! <br> 다음 단계로 넘어가자.", "good": "좋아! ", "but": "<br> 하지만, ", "try_again": " 개의 블록만으로 성공하는 방법도 있어. <br> 다시 도전해 보는건 어때?", "try_again_commands": " 개의 명렁어만으로 성공하는 방법도 있어. <br> 다시 도전해 보는건 어때?", "cfest_success": "대단한걸! 덕분에 친구들을 구할 수 있었어! <br> 아마도 너는 타고난 프로그래머 인가봐! <br> 나중에 또 만나자~!", "succeeded_and_cert": "개의 블록만으로 성공했어! <br>인증서를 받으러 가자.", "cause_msgs_1": "에구, 앞으로 갈 수 없는 곳이였어. 다시 해보자.", "cause_msgs_2": "히잉. 그냥 길에서는 뛰어 넘을 곳이 없어. 다시 해보자.", "cause_msgs_3": "에고고, 아파라. 뛰어 넘었어야 했던 곳이였어. 다시 해보자.", "cause_msgs_4": "아쉽지만, 이번 단계에서는 꼭 아래 블록을 써야만 해. <br> 다시 해볼래?", "cause_msgs_5": "이런, 실행할 블록들이 다 떨어졌어. 다시 해보자.", "cause_msgs_6": "이런, 실행할 명령어들이 다 떨어졌어. 다시 해보자.", "close_experience": "체험<br>종료", "replay": "다시하기", "go_to_next_level": "다음단계 가기", "move_forward": "앞으로 한 칸 이동", "turn_left": "왼쪽", "turn_right": "오른쪽", "turn_en": "", "turn_ko": "으로 회전", "jump_over": "뛰어넘기", "when_start_is_pressed": "시작하기를 클릭했을 때", "repeat_until_ko": "만날 때 까지 반복", "repeat_until_en": "", "repeat_until": "만날 때 까지 반복", "if_there_is_1": "만약 앞에 ", "if_there_is_2": "있다면", "used_blocks": "사용 블록", "maximum": "목표 블록", "used_command": "사용 명령어 갯수", "maximum_command": "목표 명령어 갯수", "block_box": "블록 꾸러미", "block_assembly": "블록 조립소", "command_box": "명령어 꾸러미", "command_assembly": "명령어 조립소", "start": "시작하기", "engine_running": "실행중", "engine_replay": "돌아가기", "goto_show": "보러가기", "make_together": "함께 만드는 엔트리", "make_together_content": "엔트리는 학교에 계신 선생님들과 학생 친구들이 함께 고민하며 만들어갑니다.", "project_nobody_like": "이 작품이 마음에 든다면 '좋아요'를 눌러 주세요.", "project_nobody_interest": "'관심 작품'을 누르면 마이 페이지에서 볼 수 있어요.", "lecture_nobody_like": "이 강의가 마음에 든다면 '좋아요'를 눌러 주세요.", "lecture_nobody_interest": "'관심 강의'을 누르면 마이 페이지에서 볼 수 있어요.", "course_nobody_like": "이 강의 모음이 마음에 든다면 '좋아요'를 눌러 주세요.", "course_nobody_interest": "'관심 강의 모음'을 누르면 마이 페이지에서 볼 수 있어요.", "before_changed": "변경전", "after_changed": "변경후", "from_changed": "( 2016년 04월 17일 부터 ) ", "essential": "필수", "access_term_title": "안녕하세요. 엔트리 교육연구소 입니다. <br> 엔트리를 사랑해주시는 여러분께 감사드리며,  <br> 엔트리 교육연구소 웹사이트 이용약관이<br> 2016년 4월 17일 부로 다음과 같이 개정됨을 알려드립니다. ", "member_info": "회원 안내", "personal_info": "개인정보 수집 및 이용에 동의 합니다.", "option": "선택", "news": "최신소식", "edu_material": "교육자료", "latest_news": "최근소식", "edu_data": "교육자료", "training_program": "연수지원", "footer_phrase": "엔트리는 누구나 무료로 소프트웨어 교육을 받을 수 있게 개발된 비영리 교육 플랫폼입니다.", "footer_use_free": "모든 엔트리교육연구소의 저작물은 교육적 목적에 한하여 출처를 밝히고 자유롭게 이용할 수 있습니다.", "footer_description_1": "엔트리는 비영리 교육 플랫폼으로써, 모든 엔트리의 저작물은 교육적 목적에 한하여 출처를 밝히고 자유롭게 이용할 수 있습니다.", "footer_description_2": "", "nonprofit_platform": "비영리 교육 플랫폼", "this_is": "입니다.", "privacy": "개인정보 처리방침", "entry_addr": "서울특별시 강남구 강남대로 382 메리츠타워 7층 재단법인 커넥트", "entry_addr_additional_phone": "02-6202-9783", "entry_addr_additional_email": "[email protected]", "entry_addr_additional_opensource": "Open Source License", "phone": "전화번호", "alert_agree_term": "이용약관에 동의하여 주세요.", "alert_private_policy": "개인정보 수집 약관에 동의하여 주세요.", "agree": "동의", "optional": "선택", "start_software": "소프트웨어 교육의 첫걸음", "analyze_procedure": "절차", "analyze_repeat": "반복", "analyze_condition": "분기", "analyze_interaction": "상호작용",<|fim▁hole|> "analyze_sync": "병렬 및 동기화", "jr_intro_1": "안녕! 난 쥬니라고 해! 내 친구 엔트리봇이 오른쪽에 있어! 날 친구에게 데려다 줘!", "jr_intro_2": "엔트리봇이 내 왼쪽에 있어! 왼쪽으로 가보자.", "jr_intro_3": "엔트리봇이 위쪽에 있어! 친구를 만날 수 있도록 도와줘!", "jr_intro_4": "어서 엔트리봇을 만나러 가자! 아래쪽으로 가보는거야~ ", "jr_intro_5": "우왓! 내 친구가 멀리 떨어져있어. 엔트리봇이 있는 곳까지 안내해줄래? ", "jr_intro_6": "저기 엔트리봇이 있어~ 얼른 만나러 가보자.", "jr_intro_7": "예쁜 꽃이 있네. 꽃들을 모아 엔트리봇에게 가보자!", "jr_intro_8": "가는 길에 꽃이 있어! 꽃을 모아 엔트리봇에게 가보자!", "jr_intro_9": "엔트리봇이 멀리 떨어져 있네? 가장 빠른 길로 엔트리봇에게 가 보자.", "jr_intro_10": "엔트리봇을 만나러 가는 길에 꽃을 모두 모아서 가보자.", "jr_intro_11": "엔트리봇에게 가려면 오른쪽으로 다섯번이나 가야 하잖아? 반복하기 블록을 사용해서 좀 더 쉽게 가 보자.", "jr_intro_12": "반복하기를 사용해서 엔트리봇을 만나러 가자.", "jr_intro_13": "지금 블록으로는 친구에게 갈 수가 없어. 반복 횟수를 바꿔 엔트리봇에게 갈 수 있게 해줘.", "jr_intro_14": "반복 블록을 사용하여 엔트리봇에게 데려다 줘.", "jr_intro_15": "엔트리봇이 정~말 멀리 있잖아? 그래도 반복 블록을 사용하면 쉽게 엔트리봇에게 갈 수 있을 거야.", "jr_whats_ur_name": "내가 받을 인증서에 적힐 이름은?", "jr_down_cert": "인증서 받기", "jr_popup_prefix_1": "좋아! 엔트리봇을 만났어!", "jr_popup_prefix_2": "우왓! 엔트리봇을 만났어! <br> 하지만 엔트리봇을 만나기에는 더 적은 블록을 사용해서도 <br> 만날 수 있는데 다시 해볼래? ", "jr_popup_prefix_3": "좋아! 책가방을 챙겼어!", "jr_popup_prefix_4": "우왓! 책가방이 있는 곳으로 왔어! 하지만 더 적은 블록을 사용해도 책가방 쪽으로 갈 수 있는데 다시 해볼래?", "jr_popup_suffix_1": "고마워~ 덕분에 책가방을 챙겨서 학교에 올 수 있었어~ 다음 학교 가는 길도 함께 가자~", "jr_popup_suffix": "고마워~ 덕분에 엔트리봇이랑 재밌게 놀 수 있었어~ <br>다음에 또 엔트리봇이랑 놀자~", "jr_fail_dont_go": "에궁, 그 곳으로는 갈 수 없어. 가야하는 길을 다시 알려줘~", "jr_fail_dont_know": "어? 이제 어디로 가지? 어디로 가야하는 지 더 알려줘~", "jr_fail_no_flower": "이런 그곳에는 꽃이 없어. 꽃이 있는 곳에서 사용해보자~", "jr_fail_forgot_flower": "앗! 엔트리봇한테 줄 꽃을 깜빡했어. 꽃을 모아서 가자~", "jr_fail_need_repeat": "반복 블록이 없잖아! 반복 블록을 사용해서 해보자~", "jr_hint_1": "안녕! 난 쥬니라고 해! 내 친구 엔트리봇이 오른쪽에 있어! 날 친구에게 데려다 줘!", "jr_hint_2": "엔트리봇이 내 왼쪽에 있어! 왼쪽으로 가보자.", "jr_hint_3": "엔트리봇이 위쪽에 있어! 친구를 만날 수 있도록 도와줘!", "jr_hint_4": "어서 엔트리봇을 만나러 가자! 아래쪽으로 가보는거야~", "jr_hint_5": "우왓! 내 친구가 멀리 떨어져있어. 엔트리봇이 있는 곳까지 안내해줄래?", "jr_hint_6": "잘못된 블록들 때문에 친구에게 가지 못하고 있어, 잘못된 블록을 지우고 엔트리봇에게 갈 수 있도록 해줘!", "jr_hint_7": "예쁜 꽃이 있네. 꽃들을 모아 엔트리봇에게 가보자!", "jr_hint_8": "가는 길에 꽃이 있어! 꽃을 모아 엔트리봇에게 가보자!", "jr_hint_9": "엔트리봇이 멀리 떨어져 있네? 가장 빠른 길로 엔트리봇에게 가 보자.", "jr_hint_10": "앗, 블록을 잘못 조립해서 제대로 갈 수가 없어. 가는 길에 꽃을 모두 모아 엔트리봇에게 가져다 줄 수 있도록 고쳐 보자.", "jr_hint_11": "엔트리봇에게 가려면 오른쪽으로 다섯번이나 가야 하잖아? 반복하기 블록을 사용해서 좀 더 쉽게 가 보자.", "jr_hint_12": "반복하기를 사용해서 엔트리봇을 만나러 가자.", "jr_hint_13": "지금 블록으로는 친구에게 갈 수가 없어. 반복 횟수를 바꿔 엔트리봇에게 갈 수 있게 해줘.", "jr_hint_14": "반복 블록을 사용하여 엔트리봇에게 데려다 줘.", "jr_hint_15": "엔트리봇이 정~말 멀리 있잖아? 그래도 반복 블록을 사용하면 쉽게 엔트리봇에게 갈 수 있을 거야.", "jr_certification": "인증서", "jr_congrat": "축하드립니다!", "jr_congrat_msg": "문제해결 과정을 성공적으로 마쳤습니다.", "jr_share": "공유", "go_see_friends": "친구들 만나러 가요~!", "junior_naver": "쥬니어 네이버", "junior_naver_contents_1": "의 멋진 곰 '쥬니'가 엔트리를 찾아 왔어요! ", "junior_naver_contents_2": "그런데 쥬니는 길을 찾는 것이 아직 어렵나봐요.", "junior_naver_contents_3": "쥬니가 엔트리봇을 만날 수 있도록 가야하는 방향을 알려주세요~", "basic_content": "기초", "jr_help": "도움말", "help": "도움말", "cparty_robot_intro_1": "안녕 나는 엔트리봇이야. 난 부품을 얻어서 내몸을 고쳐야해. 앞으로 가기 블록으로 부품을 얻게 도와줘!", "cparty_robot_intro_2": "좋아! 앞에도 부품이 있는데 이번에는 잘못 가다간 감전되기 쉬울 것 같아. 뛰어넘기 블록을 써서 부품까지 데려다 줘.", "cparty_robot_intro_3": "멋진걸! 저기에도 부품이 있어! 길이 조금 꼬여있지만 회전하기 블록을 쓰면 충분히 갈 수 있을 것 같아! ", "cparty_robot_intro_4": "좋아 이제 움직이는 건 많이 편해졌어! 이번에는 회전과 뛰어넘기를 같이 써서 저 부품을 얻어보자! ", "cparty_robot_intro_5": "덕분에 몸이 아주 좋아졌어! 이번에도 회전과 뛰어넘기를 같이 써야 할 거야! 어서 가보자!", "cparty_robot_intro_6": "멋져! 이제 몸이 많이 좋아져서, 똑같은 일은 여러 번 해도 괜찮을 거야! 한 번 반복하기를 사용해서 가보자!", "cparty_robot_intro_7": "어? 중간중간에 뛰어넘어야 할 곳이 있어! 그래도 반복하기로 충분히 갈 수 있을 거야!", "cparty_robot_intro_8": "이런! 이번에는 부품이 저기 멀리 떨어져 있어. 그래도 반복하기를 사용하면 쉽게 갈수 있지! 얼른 도와줘!", "cparty_robot_intro_9": "우와~ 이제 내 몸이 거의 다 고쳐진 것 같아! 이번에도 반복하기를 이용해서 부품을 구하러 가보자!", "cparty_robot_intro_10": "대단해! 이제 마지막 부품만 있으면 내 몸을 완벽하게 고칠 수 있을 거야! 빨리 반복하기로 도와줘!", "cparty_car_intro_1": "안녕! 나는 엔트리봇이라고 해, 자동차를 타고 계속 이동하려면 연료가 필요해! 앞에 있는 연료를 얻을 수 있게 도와줄래?", "cparty_car_intro_2": "좋아! 그런데 이번에는 길이 직선이 아니네! 왼쪽/오른쪽 돌기 블록으로 잘 운전해서 함께 연료를 얻으러 가볼까?", "cparty_car_intro_3": "잘했어! 이번 길 앞에는 과속방지턱이 있어. 빠르게 운전하면 사고가 날 수도 있을 것 같아, 천천히 가기 블록을 써서 연료를 얻으러 가보자!", "cparty_car_intro_4": "야호, 이제 운전이 한결 편해졌어! 이 도로에서는 반복하기 블록을 사용해서 연료를 채우러 가볼까?", "cparty_car_intro_5": "와 이번 도로는 조금 복잡해 보이지만, 앞으로 가기와 왼쪽/오른쪽 돌기 블록을 반복하면서 가보면 돼! 차분하게 연료까지 가보자", "cparty_car_intro_6": "이번에는 도로에 장애물이 있어서 잘 돌아가야 될 것 같아, 만약에 장애물이 앞에 있다면 어떻게 해야 하는지 알려줘!", "cparty_car_intro_7": "좋아 잘했어! 한번 더 만약에 블록을 사용해서 장애물을 피해 연료를 얻으러 가보자!", "cparty_car_intro_8": "앗 아까 만났던 과속 방지턱이 두 개나 있네, 천천히 가기 블록을 이용해서 안전하게 연료를 채우러 가보자!", "cparty_car_intro_9": "복잡해 보이는 길이지만, 앞에서 사용한 반복 블록과 만약에 블록을 잘 이용하면 충분히 운전할 수 있어, 연료를 채울 수 있도록 도와줘!", "cparty_car_intro_10": "정말 멋져! 블록의 순서를 잘 나열해서 이제 마지막 남은 연료를 향해 힘을 내어 가보자!", "cparty_car_popup_prefix_1": "좋아! 연료를 얻었어!", "cparty_car_popup_prefix_2": "우왓! 연료를 얻었어! <br> 하지만 연료를 얻기에는 더 적은 블록을 사용해서도 <br> 얻을 수 있는데 다시 해볼래? ", "cparty_car_popup_prefix_2_text": "우왓! 연료를 얻었어! <br> 하지만 연료를 얻기에는 더 적은 명령어 사용해서도 <br> 얻을 수 있는데 다시 해볼래? ", "cparty_car_popup_suffix": "고마워~ 덕분에 모든 배터리를 얻을 수 있었어~ <br>다음에 또 나랑 놀자~", "all_grade": "모든 학년", "grade_e3_e4": "초등 3 ~ 4 학년 이상", "grade_e5_e6": "초등 5 ~ 6 학년 이상", "grade_m1_m3": "중등 1 ~ 3 학년 이상", "entry_first_step": "엔트리 첫걸음", "entry_monthly": "월간 엔트리", "play_sw_2": "EBS 소프트웨어야 놀자2", "entry_programming": "실전, 프로그래밍!", "entry_recommanded_course": "엔트리 추천 코스", "introduce_course": "누구나 쉽게 보고 따라하면서 재미있고 다양한 소프트웨어를 만들 수 있는 강의 코스를 소개합니다.", "all_free": "*강의 동영상, 만들기, 교재 등이 모두 무료로 제공됩니다.", "cparty_result_fail_1": "에궁, 그 곳으로는 갈 수 없어. 가야하는 길을 다시 알려줘~", "cparty_result_fail_2": "에고고, 아파라. 뛰어 넘었어야 했던 곳이였어. 다시 해보자.", "cparty_result_fail_3": "아이고 힘들다. 아래 블록들을 안 썼더니 너무 힘들어! 아래 블록들로 다시 만들어줘.", "cparty_result_fail_4": "어? 이제 어디로 가지? 어디로 가야하는 지 더 알려줘~", "cparty_result_fail_5": "앗! 과속방지턱에서는 속도를 줄여야해. 천천히 가기 블록을 사용해보자~", "cparty_result_success_1": "좋아! 부품을 얻었어!", "cparty_result_success_2": "우왓! 부품을 얻었어! <br>하지만 부품을 얻기에는 더 적은 블록을 사용해서도 얻을 수 있는데 다시 해볼래?", "cparty_result_success_2_text": "우왓! 부품을 얻었어! <br>하지만 부품을 얻기에는 더 적은 명령어를 사용해서도 얻을 수 있는데 다시 해볼래?", "cparty_result_success_3": "고마워~ 덕분에 내몸이 다 고쳐졌어~ 다음에 또 나랑 놀자~", "cparty_insert_name": "이름을 입력하세요.", "offline_file": "파일", "offline_edit": "편집", "offline_undo": "되돌리기", "offline_redo": "다시실행", "offline_quit": "종료", "select_one": "선택해 주세요.", "evaluate_challenge": "도전해본 미션의 난이도를 평가해 주세요.", "very_easy": "매우쉬움", "easy": "쉬움", "normal": "보통", "difficult": "어려움", "very_difficult": "매우 어려움", "save_dismiss": "바꾼 내용을 저장하지 않았습니다. 계속 하시겠습니까?", "entry_info": "엔트리 정보", "actual_size": "실제크기", "zoom_in": "확대", "zoom_out": "축소", "cparty_jr_intro_1": "안녕! 난 엔트리봇 이라고 해! 학교가는 길에 책가방을 챙길 수 있도록 도와줘! ", "cparty_jr_intro_2": "책가방이 내 왼쪽에 있어! 왼쪽으로 가보자.", "cparty_jr_intro_3": "책가방이 위쪽에 있어! 책가방을 챙길 수 있도록 도와줘!", "cparty_jr_intro_4": "어서 책가방을 챙기러 가자! 아래쪽으로 가보는 거야~", "cparty_jr_intro_5": "우왓! 내 책가방이 멀리 떨어져 있어. 책가방이 있는 곳까지 안내해줄래?", "cparty_jr_intro_6": "책가방이 있어! 얼른 가지러 가자~", "cparty_jr_intro_7": "길 위에 내 연필이 있네. 연필들을 모아 책가방을 챙기러 가보자!", "cparty_jr_intro_8": "학교 가는 길에 연필이 있어! 연필을 모아 책가방을 챙기러 가보자!", "cparty_jr_intro_9": "내 책가방이 멀리 떨어져 있네? 가장 빠른 길로 책가방을 챙기러 가 보자.", "cparty_jr_intro_10": "가는 길에 연필을 모두 모으고 책가방을 챙기자!", "cparty_jr_intro_11": "책가방을 챙기러 가려면 오른쪽으로 다섯 번이나 가야 하잖아? 반복하기 블록을 사용해서 좀 더 쉽게 가 보자.", "cparty_jr_intro_12": "반복하기를 사용해서 책가방을 챙기러 가자.", "cparty_jr_intro_13": "지금 블록으로는 책가방이 있는 쪽으로 갈 수가 없어. 반복 횟수를 바꿔 책가방을 챙기러 갈 수 있게 해줘.", "cparty_jr_intro_14": "반복 블록을 사용하여 책가방을 챙기러 가줘.", "cparty_jr_intro_15": "학교가 정~말 멀리 있잖아? 그래도 반복 블록을 사용하면 쉽게 학교에 도착 할수 있을 거야.", "make_new_project": "새로운 작품 만들기", "open_old_project": "저장된 작품 불러오기", "offline_download": "엔트리 다운로드", "offline_release": "엔트리 오프라인 에디터 출시!", "offline_description_1": "엔트리 오프라인 버전은", "offline_description_2": "인터넷이 연결되어 있지 않아도 사용할 수 있습니다. ", "offline_description_3": "지금 다운받아서 시작해보세요!", "sw_week_2015": "2015 소프트웨어교육 체험 주간", "cparty_desc": "두근두근 소프트웨어와의 첫만남", "entry_offline_download": "엔트리 오프라인 \n다운로드", "entry_download_detail": "다운로드\n바로가기", "offline_desc_1": "엔트리 오프라인 버전은 인터넷이 연결되어 있지 않아도 사용할 수 있습니다.", "offline_desc_2": "지금 다운받아서 시작해보세요!", "download": "다운로드", "version": "버전", "file_size": "크기", "update": "업데이트", "use_range": "사용범위", "offline_desc_free": "엔트리 오프라인은 기업과 개인 모두 제한 없이 무료로 사용하실 수 있습니다.", "offline_required": "최소 요구사항", "offline_required_detail": "디스크 여유 공간 500MB 이상, windows7 혹은 MAC OS 10.8 이상", "offline_notice": "설치 전 참고사항", "offline_notice_1": "1. 버전", "offline_notice_1_1": "에서는 하드웨어 연결 프로그램이 내장되어 있습니다.", "offline_notice_2": "2. 별도의 웹브라우져가 필요하지 않습니다.", "offline_notice_3": "버전 별 변경 사항 안내", "offline_notice_4": "버전별 다운로드", "offline_notice_5": "버전별 자세한 변경 사항 보기", "hardware_online_badge": "온라인", "hardware_title": "엔트리 하드웨어 연결 프로그램 다운로드", "hardware_desc": "엔트리 온라인 ‘작품 만들기’에서 하드웨어를 연결하여 엔트리를 이용하는 경우에만 별도로 설치가 필요합니다.", "hardware_release": "하드웨어 연결 프로그램의 자세한 변경 사항은 아래 주소에서 확인 할 수 있습니다.", "hardware_window_download": "Windows 다운로드", "hardware_osx_download": "Mac 다운로드", "cparty_jr_result_2": "고마워~ 덕분에 책가방을 챙겨서 학교에 올 수 있었어~ <br>다음 학교 가는 길도 함께 가자~ ", "cparty_jr_result_3": "우왓! 학교까지 왔어! <br>하지만 더 적은 블록을 사용해도 학교에 갈 수 있는데<br> 다시 해볼래?", "cparty_jr_result_4": "우왓! 책가방을 얻었어!<br> 하지만 더 적은 블록을 사용해도 책가방을 얻을 수 있는데 <br>다시 해볼래? ", "lms_no_class": "아직 만든 학급이 없습니다.", "lms_create_class": "학급을 만들어 주세요.", "lms_add_class": "학급 만들기", "lms_base_class": "기본", "lms_delete_class": "삭제", "lms_my_class": "나의 학급", "lms_grade_1": "초등 1", "lms_grade_2": "초등 2", "lms_grade_3": "초등 3", "lms_grade_4": "초등 4", "lms_grade_5": "초등 5", "lms_grade_6": "초등 6", "lms_grade_7": "중등 1", "lms_grade_8": "중등 2", "lms_grade_9": "중등 3", "lms_grade_10": "일반", "lms_add_groupId_personal": "선생님께 받은 학급 아이디를 입력하여, 회원 정보에 추가하세요.", "lms_add_groupId": "학급 아이디 추가하기", "lms_add_group_account": "학급 계정 추가", "lms_enter_group_info": "발급받은 학급 아이디와 비밀번호를 입력하세요.", "lms_group_id": "학급 아이디", "lms_group_pw": "비밀번호", "lms_group_name": "소속 학급명", "personal_pwd_alert": "올바른 비밀번호 양식을 입력해 주세요", "personal_form_alert": "양식을 바르게 입력해 주세요", "personal_form_alert_2": "모든 양식을 완성해 주세요", "personal_no_pwd_alert": "비밀번호를 입력해 주세요", "select_gender": "성별을 선택해 주세요", "enter_group_id": "학급 아이디를 입력해 주세요", "enter_group_pwd": "비밀번호를 입력해 주세요", "info_added": "추가되었습니다", "no_group_id": "학급 아이디가 존재하지 않습니다", "no_group_pwd": "비밀번호가 일치하지 않습니다", "lms_please_choice": "선택해 주세요.", "group_lesson": "나의 학급 강의", "lms_banner_add_group": "학급 기능 도입", "lms_banner_entry_group": "엔트리 학급 만들기", "lms_banner_desc_1": "우리 반 학생들을 엔트리에 등록하세요!", "lms_banner_desc_2": "이제 보다 편리하고 쉽게 우리 반 학생들의 작품을 찾고,", "lms_banner_desc_3": "성장하는 모습을 확인할 수 있습니다. ", "lms_banner_download_manual": "메뉴얼 다운로드", "lms_banner_detail": "자세히 보기", "already_exist_email": "이미 존재하는 이메일 입니다.", "remove_project": "작품을 삭제하시겠습니까?", "study_lesson": "우리 반 학습하기", "open_project": "작품 불러오기", "make_group": "학급 만들기", "project_share": "작품 공유하기", "group_project_share": "학급 공유하기", "group_discuss": "학급 글 나누기", "my_profile": "마이 페이지", "search_updated": "최신 작품", "search_recent": "최근 조회수 높은 작품", "search_complexity": "최근 제작에 공들인 작품", "search_staffPicked": "스태프선정 작품 저장소", "search_childCnt": "사본이 많은 작품", "search_likeCnt": "최근 좋아요가 많은 작품", "search_recentLikeCnt": "최근 좋아요가 많은 작품", "gnb_share": "공유하기", "gnb_community": "커뮤니티", "lms_add_lectures": "강의 올리기", "lms_add_course": "강의 모음 올리기", "lms_add_homework": "과제 올리기", "remove_lecture_confirm": "강의를 정말 삭제하시겠습니까?", "popup_delete": "삭제하기", "remove_course_confirm": "강의 모음을 정말 삭제하시겠습니까?", "lms_no_lecture_teacher_1": "추가된 강의가 없습니다.", "lms_no_lecture_teacher_2": "우리 반 강의를 추가해 주세요.", "gnb_download": "다운로드", "lms_no_lecture_student_1": "아직 올라온 강의가 없습니다.", "lms_no_lecture_student_2": "선생님이 강의를 올려주시면,", "lms_no_lecture_student_3": "학습 내용을 확인할 수 있습니다.", "lms_no_class_teacher": "아직 만든 학급이 없습니다.", "lms_no_course_teacher_1": "추가된 강의 모음이 없습니다.", "lms_no_course_teacher_2": "우리 반 강의 모음을 추가해 주세요.", "lms_no_course_student_1": "아직 올라온 강의 모음이 없습니다.", "lms_no_course_student_2": "선생님이 강의 모음을 올려주시면,", "lms_no_course_student_3": "학습 내용을 확인할 수 있습니다.", "lms_no_hw_teacher_1": "추가된 과제가 없습니다.", "lms_no_hw_teacher_2": "우리 반 과제를 추가해 주세요.", "lms_no_hw_student_1": "아직 올라온 과제가 없습니다.", "lms_no_hw_student_2": "선생님이 과제를 올려주시면,", "lms_no_hw_student_3": "학습 내용을 확인할 수 있습니다.", "modal_edit": "수정하기", "modal_deadline": "마감일 설정", "modal_hw_desc": "상세설명 (선택)", "desc_optional": "", "modal_create_hw": "과제 만들기", "vol": "회차", "hw_title": "과제명", "hw_description": "내용", "deadline": "마감일", "do_homework": "과제하기", "hw_progress": "진행 상태", "hw_submit": "제출", "view_list": "명단보기", "view_desc": "내용보기", "do_submit": "제출하기", "popup_notice": "알림", "no_selected_hw": "선택된 과제가 없습니다.", "hw_delete_confirm": "선택한 과제를 정말 삭제하시겠습니까?", "hw_submitter": "과제 제출자 명단", "hw_student_desc_1": "* '제출하기'를 눌러 제출을 완료하기 전까지 얼마든지 수정이 가능합니다", "hw_student_desc_2": "* 제출 기한이 지나면 과제를 제출할 수 없습니다.", "popup_create_class": "학급 만들기", "class_name": "학급 이름", "image": "이미지", "select_class_image": "학급 이미지를 선택해 주세요.", "type_class_description": "학급 소개 입력", "set_as_primary_group": "기본학급으로 지정", "set_primary_group": "지정", "not_primary_group": "지정안함", "type_class_name": "학급 이름을 입력해주세요. ", "type_class_description_long": "학급 소개를 입력해 주세요. 170자 이내", "add_students": "학생 추가하기", "invite_students": "학생 초대하기", "invite_with_class": "1. 학급 코드로 초대하기", "invite_code_expiration": "코드 만료시간", "generate_code_button": "코드재발급", "generate_code_desc": "학생의 학급 코드 입력 방법", "generate_code_desc1": "엔트리 홈페이지에서 로그인을 해주세요.", "generate_code_desc2": "메뉴바에서<나의 학급>을 선택해주세요.", "generate_code_desc3": "<학급코드 입력하기>를 눌러 학급코드를 입력해주세요.", "invite_with_url": "2. 학급 URL로 초대하기", "copy_invite_url": "복사하기", "download_as_pdf": "학급계정 PDF로 내려받기", "download_as_excel": "학급계정 엑셀로 내려받기", "temp_password": "임시 비밀번호 발급", "step_name": "이름 입력", "step_info": "정보 추가/수정", "preview": "미리보기", "type_name_enter": "학급에 추가할 학생의 이름을 입력하고 엔터를 치세요.", "multiple_name_possible": "여러명의 이름 입력이 가능합니다.", "id_auto_create": "학번은 별도로 수정하지 않으면 자동으로 생성됩니다.", "student_id_desc_1": "학급 아이디는 별도의 입력없이 자동으로 생성됩니다.", "student_id_desc_2": "단, 엔트리에 이미 가입된 학생을 학급에 추가한다면 학생의 엔트리 아이디를", "student_id_desc_3": "입력해주세요. 해당 학생은 로그인 후, 학급 초대를 수락하면 됩니다.", "student_number": "학번", "temp_password_desc_1": "임시 비밀번호로 로그인 후,", "temp_password_desc_2": "신규 비밀번호를 다시 설정할 수 있도록 안내해주세요.", "temp_password_desc_3": "*한번 발급된 임시 비밀번호는 다시 볼 수 없습니다.", "temp_password_demo": "로그인 불가능한 안내 용 예시 계정입니다.", "temp_works": "작품 보기", "student_delete_confirm": "학생을 정말 삭제하시겠습니까?", "no_student_selected": "선택된 학생이 없습니다.", "class_assignment": "학급 과제", "class_list": "학급 목록", "select_grade": "학년을 선택 하세요.", "add_project": "작품 공유하기", "no_project_display": "학생들이 전시한 작품이 없습니다.", "plz_display_project": "나의 작품을 전시해 주세요.", "refuse_confirm": "학급 초대를 정말 거절하시겠습니까?", "select_class": "학급 선택", "group_already_registered": "이미 가입된 학급입니다.", "mon": "월", "tue": "화", "wed": "수", "thu": "목", "fri": "금", "sat": "토", "sun": "일", "jan": "1월", "feb": "2월", "mar": "3월", "apr": "4월", "may": "5월", "jun": "6월", "jul": "7월", "aug": "8월", "sep": "9월", "oct": "10월", "nov": "11월", "dec": "12월", "plz_select_lecture": "강의를 선택해 주세요.", "plz_set_deadline": "마감일을 설정해 주세요.", "hide_entry": "엔트리 가리기", "hide_others": "기타 가리기", "show_all": "모두 보기", "lecture_description": "선생님들이 직접 만드는 엔트리 학습 공간입니다. 강의에서 예시작품을 보고 작품을 만들며 배워 보세요.", "curriculum_description": "학습 순서와 주제에 따라 여러 강의가 모아진 학습 공간입니다. 강의 모음의 순서에 맞춰 차근차근 배워보세요.", "linebreak_off_desc_1": "글상자의 크기가 글자의 크기를 결정합니다.", "linebreak_off_desc_2": "내용을 한 줄로만 작성할 수 있습니다.", "linebreak_off_desc_3": "새로운 글자가 추가되면 글상자의 좌우 길이가 길어집니다.", "linebreak_on_desc_1": "글상자의 크기가 글자가 쓰일 수 있는 영역을 결정합니다.", "linebreak_on_desc_2": "내용 작성시 엔터키로 줄바꿈을 할 수 있습니다.", "linebreak_on_desc_3": "내용을 작성하시거나 새로운 글자를 추가시 길이가 글상자의 가로 영역을 넘어서면 자동으로 줄이 바뀝니다.", "not_supported_text": "해당 글씨체는 한자를 지원하지 않습니다.", "entry_with": "함께 만드는 엔트리", "ebs_season_1": "시즌 1 보러가기", "ebs_season_2": "시즌 2 보러가기", "hello_ebs": "헬로! EBS 소프트웨어", "hello_ebs_desc": "<헬로! EBS 소프트웨어> 엔트리 버전의 양방향 서비스를 만나보세요! \n <헬로! EBS 소프트웨어>의 동영상 강의를 통해 \n 소프트웨어 코딩의 기본 개념을 배운 후 양방향 코딩 미션에 도전하세요!\n 방송에서는 볼 수 없었던 <대.소.동> 친구들의 \n 비하인드 스토리를 볼 수 있습니다!", "hello_ebs_sub_1": "EBS 중학 엔트리 버전의 양방향 서비스를 ", "hello_ebs_sub_2": "만나보세요! ", "visang_edu_entry": "비상교육 엔트리 학습하기", "cmass_edu_entry": "씨마스 엔트리 학습하기", "chunjae_edu_entry": "천재교과서 엔트리 학습하기", "partner": "파트너", "project_term_popup_title": "작품 공개에 따른 엔트리 저작권 정책 동의", "project_term_popup_description_1": "작품 공개를 위해", "project_term_popup_description_2": "아래 정책을 확인해주세요.", "project_term_popup_description_3": "", "project_term_popup_description_4": "", "project_term_agree_1_1": "내가 만든 작품과 그 소스코드의 공개를 동의합니다.", "project_term_agree_2_1": "다른 사람이 나의 작품을 이용하는 것을 허락합니다.", "project_term_agree_2_2": "( 복제 , 배포 , 공중송신 포함 )", "project_term_agree_3_1": "다른 사람이 나의 작품을 수정하는 것을 허락합니다.", "project_term_agree_3_2": "( 리믹스, 변형, 2차 제작물 작성 포함)", "agree_all": "전체 동의", "select_login": "로그인 선택", "select": "선택하세요", "with_login": "로그인 하고", "without_login": "로그인 안하고", "start_challenge": "미션 도전하기", "start_challenge_2": "미션 도전하기", "if_not_save_not_login": "* 로그인을 안하고 미션에 참여하시면 진행 상황이 저장되지 않습니다.", "if_not_member_yet": "엔트리 회원이 아니라면?", "join_entry": "엔트리 회원 가입하기", "learned_computing": "기존에 소프트웨어 교육을 받아보셨나요?", "cparty_index_description_1": "두근두근 소프트웨어와 첫 만남.", "cparty_index_description_2": "소프트웨어랑 재미있게 놀다 보면 소프트웨어의 원리도 배우고, 생각하는 힘도 쑥쑥!", "cparty_index_description_3": "엔트리를 통해 코딩 미션에 도전하고 인증서 받으세요.", "cparty_index_description_4": "2015 Online Coding Party는", "cparty_index_description_5": "SW교육 체험 주간", "cparty_index_description_6": "의 일환으로써,", "cparty_index_description_7": "초등컴퓨팅교사협회", "cparty_index_description_8": "과 함께 만들어졌습니다.", "cparty_index_description_9": "2016 Online Coding Party는", "cparty_index_description_10": "2017 Online Coding Party는", "cparty_index_description_11": "'SW교육을 준비하는 선생님들의 모임'", "congratulation": "축하 드립니다!", "warm_up": "체험", "beginner": "입문", "intermediate": "기본", "advanced": "발전", "applied": "응용", "cert_msg_tail": "과정을 성공적으로 마쳤습니다.", "cert_msg_head": "", "maze_text_content_1": "안녕? 나는 엔트리봇이야. 지금 나는 공장에서 탈출을 해야 해! 탈출하기 위해서 먼저 몸을 고쳐야 할 것 같아. 앞에 있는 부품을 얻을 수 있게 도와줄래? move()", "maze_text_content_2": "좋아 아주 잘했어! 덕분에 몸이 한결 가벼워졌어! 이번에도 부품상자까지 나를 이동시켜줘. 그런데 가는길에 장애물이 있어. 장애물 앞에서는 jump()", "maze_text_content_3": "멋진걸! 저기에도 부품이 있어! 길이 조금 꼬여있지만 오른쪽, 왼쪽으로 회전할 수 있는 right(); left(); 명령어를 쓰면 충분히 갈 수 있을것 같아!", "maze_text_content_4": "좋아 이제 움직이는 건 많이 편해졌어! 이번에는 지금까지 배운 명령어를 같이 써서 저 부품상자까지 가보자!", "maze_text_content_5": "우와 부품이 두 개나 있잖아! 두 개 다 챙겨서 가자! 그러면 몸을 빨리 고칠 수 있을 것 같아!", "maze_text_content_6": "이번이 마지막 부품들이야! 저것들만 있으면 내 몸을 다 고칠 수 있을 거야! 이번에도 도와줄 거지?", "maze_text_content_7": "덕분에 몸이 아주 좋아졌어! 이제 똑같은 일을 여러 번 반복해도 무리는 없을 거야. 어? 그런데 앞에 있는 저 로봇은 뭐지? 뭔가 도움이 필요한 것 같아! 도와주자! for 명령어를 사용해서 저 친구한테 나를 데려다줘!", "maze_text_content_8": "좋아! 덕분에 친구 로봇을 살릴 수 있었어! 하지만 앞에도 도움이 필요한 친구가 있네, 하지만 이번에는 벌집이 있으니까 조심해서 벌집에 안 닿게 뛰어넘어가자! 할 수 있겠지? 이번에도 for 명령어를 사용해서 친구가 있는곳까지 나를 이동시켜줘!", "maze_text_content_9": "이번에는 for 명령어 대신 미션이 끝날때까지 같은 일을 반복하도록 하는 while 명령어를 사용해봐! 나를 친구에게 데려다주면 미션이 끝나!", "maze_text_content_10": "이번에는 if 명령어가 나왔어! if와 while 명령어를 사용해서 내가 언제 어느 쪽으로 회전해야 하는지 알려줘!", "maze_text_content_11": "좋아 아까 했던 것처럼 해볼까? 언제 왼쪽으로 돌아야 하는지 알려줄 수 있겠어?", "maze_text_content_12": "이번에는 중간중간 벌집(bee)이 있네? 언제 뛰어넘어가야 할지 알려줄래?", "maze_text_content_13": "여기저기 도움이 필요한 친구들이 많이 있네! 모두 가서 도와주자!", "maze_text_content_14": "우와 이번에도 도와줘야 할 친구들이 많네. 먼저 조그마한 사각형을 돌도록 명령어를 만들고 만든 걸 반복해서 모든 친구를 구해보자.", "maze_text_content_15": "오래 움직이다 보니 벌써 지쳐버렸어. 자주 쓰는 명령어를 function 명령어를 사용해서 함수로 만들어 놓았어! 함수를 사용하여 나를 배터리 까지 이동시켜줘!", "maze_text_content_16": "좋아 멋진걸! 그럼 이번에는 함수에 들어갈 명령어들을 넣어서 나를 배터리까지 이동시켜줘!", "maze_text_content_17": "좋아 이번에는 함수를 만들고, 함수를 사용해서 배터리를 얻을 수 있도록 도와줘! 함수를 만들때 jump();를 잘 섞어봐!", "maze_text_content_18": "이번에는 길이 좀 복잡한걸? 그래도 언제 left();를 쓰고, 언제 right();를 쓰면 되는지 알려만 주면 배터리 까지 갈 수 있겠어!.", "maze_text_content_19": "이번에는 함수가 미리 정해져 있어! 그런데 함수만 써서 배터리까지 가기 힘들것 같아. 함수와 다른 명령어들을 섞어 써서 배터리 까지 이동시켜줘!", "maze_text_content_20": "좋아! 지금까지 정말 멋지게 잘 해줬어. 덕분에 이제 마지막 배터리만 채우면 앞으로는 충전이 필요 없을 거야. 함수를 이용해서 저 배터리를 얻고 내가 자유롭게 살 수 있도록 도와줘!", "maze_content_1": "안녕 나는 엔트리봇이라고 해. 지금 나는 공장에서 탈출하려는데 먼저 몸을 고쳐야 할 것 같아. 앞에 있는 부품을 얻을 수 있게 도와줄래? 앞으로 가기 블록을 조립하고 시작을 눌러봐.", "maze_content_2": "좋아 아주 잘했어! 덕분에 몸이 한결 가벼워졌어! 앞에도 부품이 있는데 이번에는 잘못 가다간 감전되기 쉬울 것 같아. 한 번 장애물 뛰어넘기 블록을 써서 부품까지 가볼까?", "maze_content_3": "멋진걸! 저기에도 부품이 있어! 길이 조금 꼬여있지만 회전하기 블록을 쓰면 충분히 갈 수 있을 것 같아! 이번에도 도와줄 거지?", "maze_content_4": "좋아 이제 움직이는 건 많이 편해졌어! 이번에는 회전과 뛰어넘기를 같이 써서 저 부품을 얻어보자!", "maze_content_5": "우와 부품이 두 개나 있잖아! 두 개 다 챙겨서 가자! 그러면 몸을 빨리 고칠 수 있을 것 같아!", "maze_content_6": "이번이 마지막 부품들이야! 저것들만 있으면 내 몸을 다 고칠 수 있을 거야! 이번에도 도와줄 거지?", "maze_content_7": "덕분에 몸이 아주 좋아졌어! 이제 똑같은 일을 여러 번 반복해도 무리는 없을 거야. 어? 그런데 앞에 있는 저 로봇은 뭐지? 뭔가 도움이 필요한 것 같아! 도와주자! 얼른 반복하기의 숫자를 바꿔서 저 친구한테 나를 데려다줘!", "maze_content_8": "좋아! 덕분에 친구 로봇을 살릴 수 있었어! 하지만 앞에도 도움이 필요한 친구가 있는 것 같아, 하지만 이번에는 벌집이 있으니까 조심해서 벌집에 안 닿게 뛰어넘어가자! 할 수 있겠지? 그럼 아까 했던 것처럼 반복을 써서 친구한테 갈 수 있게 해줄래?", "maze_content_9": "이번에는 숫자만큼 반복하는 게 아니라 친구 로봇한테 갈 때까지 똑같은 일을 반복할 수 있어! 이번에도 친구를 구할 수 있도록 도와줘!", "maze_content_10": "이번에는 만약 블록이란 게 있어! 만약 블록을 써서 언제 어느 쪽으로 돌아야 하는지 알려줘!", "maze_content_11": "좋아 아까 했던 것처럼 해볼까? 언제 왼쪽으로 돌아야 하는지 알려줄 수 있겠어?", "maze_content_12": "이번에는 중간중간 벌집이 있네? 언제 뛰어넘어가야 할지 알려줄래?", "maze_content_13": "여기저기 도움이 필요한 친구들이 많이 있네! 모두 도와주자!", "maze_content_14": "우와 이번에도 도와줘야 할 친구들이 많네. 먼저 조그마한 사각형을 돌도록 블록을 만들고 만든 걸 반복해서 모든 친구를 구해보자.", "maze_content_15": "반복을 하도 많이 했더니 자주 쓰는 블록은 외울 수 있을 것 같아! 약속 블록은 지금 내가 외운 블록들이야! 일단은 오래 움직여서 지쳤으니까 배터리를 좀 채울 수 있게 약속 호출 블록을 써서 배터리를 채울 수 있게 해줘!", "maze_content_16": "좋아 멋진걸! 그럼 이번에는 네가 자주 쓰일 블록을 나한테 가르쳐줘! 약속 정의 블록 안에 자주 쓰일 블록을 넣어보면 돼!", "maze_content_17": "좋아 이번에도 그러면 약속을 이용해서 배터리를 얻을 수 있도록 도와줄 거지? 약속에 뛰어넘기를 잘 섞어봐!", "maze_content_18": "이번에는 길이 좀 복잡한걸? 그래도 언제 왼쪽으로 돌고, 언제 오른쪽으로 돌면 되는지 알려만 주면 충전할 수 있을 것 같아.", "maze_content_19": "이번에는 약속이 미리 정해져 있어! 그런데 바로 약속을 쓰기에는 안될 것 같아. 내가 갈 길을 보고 약속을 쓰면 배터리를 채울 수 있을 것 같은데 도와줄 거지?", "maze_content_20": "좋아! 지금까지 정말 멋지게 잘 해줬어. 덕분에 이제 마지막 배터리만 채우면 앞으로는 충전이 필요 없을 거야. 그러니까 약속을 이용해서 저 배터리를 얻고 내가 자유롭게 살 수 있도록 도와줄래?", "maze_content_21": "안녕? 나는 엔트리 봇이야. 지금 많은 친구들이 내 도움을 필요로 하고 있어. 반복하기를 이용해서 친구들을 도울수 있게 데려다 줘!", "maze_content_22": "고마워! 이번에는 벌집을 뛰어넘어서 친구를 구하러 갈 수 있게 도와줘!", "maze_content_23": "좋아! 이번에는 친구 로봇한테 갈 때까지 반복하기를 이용해서 친구를 도울 수 있게 도와줘!", "maze_content_24": "안녕! 나는 엔트리 봇이야. 지금 나는 너무 오래 움직여서 배터리를 채워야 해. 약속 불러오기를 써서 배터리를 채울 수 있도록 도와줘!", "maze_content_25": "멋져! 이번에는 여러 약속을 불러와서 배터리가 있는 곳까지 가보자!", "maze_content_26": "좋아! 이제 약속할 블록을 나한테 가르쳐줘! 약속하기 블록 안에 자주 쓰일 블록을 넣으면 돼!", "maze_content_27": "지금은 미리 약속이 정해져 있어. 그런데, 약속을 쓰기위해서는 내가 갈 방향을 보고 약속을 사용해야해. 도와줄거지?", "maze_content_28": "드디어 마지막이야! 약속을 이용하여 마지막 배터리를 얻을 수 있게 도와줘!", "ai_content_1": "안녕? 나는 엔트리봇이라고 해. 우주 탐사를 마치고 지구로 돌아가려는데 우주를 떠다니는 돌들 때문에 쉽지 않네. 내가 안전하게 집에 갈 수 있도록 도와줄래? 나의 우주선에는 나의 앞과 위, 아래에 무엇이 어느 정도의 거리에 있는지 알려주는 레이더가 있어 너의 판단을 도와줄 거야!", "ai_content_2": "고마워! 덕분에 돌을 쉽게 피할 수 있었어. 그런데 이번엔 더 많은 돌이 있잖아? 블록들을 조립하여 돌들을 이리저리 잘 피해 보자!", "ai_content_3": "좋았어! 안전하게 돌을 피했어. 그런데 앞을 봐! 아까보다 더 많은 돌이 있어. 하지만 걱정하지 마. 나에게 반복하기 블록이 있거든. 반복하기 블록 안에 움직이는 블록을 넣으면 목적지에 도착할 때까지 계속 움직일게!", "ai_content_4": "대단해! 반복하기 블록을 쓰니 많은 돌을 피하기가 훨씬 수월한걸! 하지만 이렇게 일일이 조종하기는 피곤하다. 나에겐 레이더가 있으니 앞으로 무엇이 나올지 알 수 있어. 앞으로 계속 가다가 앞에 돌이 있으면 피할 수 있도록 해줄래?", "ai_content_5": "잘했어! 여기까지 와서 아주 기뻐. 이번에는 레이더가 앞에 있는 물체까지의 거리를 말해줄 거야. 이 기능을 사용하여 돌을 피해 보자! 돌까지의 거리가 멀 때는 앞으로 계속 가다가, 거리가 가까워지면 피할 수 있도록 해줄래?", "ai_content_6": "와~ 멋진걸? 레이더를 활용하여 돌을 잘 피해 나가고 있어! 이번에는 여러 개의 레이더를 사용하여 이리저리 돌들을 피해 나갈 수 있게 만들어줄래?", "ai_content_7": "휴~ 지구에 점점 가까워지고 있어! 돌을 피할 때 기왕이면 더 안전한 길로 가고 싶어! 아마도 돌이 더 멀리 있는 쪽이 더 안전한 길이겠지? 위쪽 레이더와 아래쪽 레이더를 비교하여 더 안전한 쪽으로 움직이도록 해줄래?", "ai_content_8": "좋아! 덕분에 무사히 비행하고 있어. 어? 그런데 저게 뭐지? 저건 내가 아주 위급한 상황에서 사용할 수 있는 특별한 에너지야! 이번에는 저 아이템들을 모두 모으며 움직이자!", "ai_content_9": "훌륭해! 이제 지구까지 얼마 안 남았어. 그런데 앞을 보니 돌들로 길이 꽉 막혀서 지나갈 수가 없잖아? 하지만 걱정하지 마. 아이템을 획득해서 사용하면 앞에 있는 꽉 막힌 돌들을 없앨 수 있다고!", "ai_content_10": "좋아! 드디어 저기 지구가 보여! 이럴 수가! 이제는 날아오는 돌들을 미리 볼 수가 없잖아? 돌들이 어떻게 날아올지 알지 못해도 지금까지처럼만 움직이면 잘 피할 수 있을 것 같아! 지구까지 가보는 거야!", "maze_hints_title_1": "시작 방법", "maze_hints_content_1": "엔트리봇은 어떻게 움직이나요?", "maze_hints_detail_1": "1. 블록 꾸러미에서 원하는 블록을 꺼내어 “시작하기를 클릭했을 때” 블록과 연결해봐<br>2. 다 조립했으면, 시작을 눌러봐<br>3. 나는 네가 조립한 블록대로 위에서부터 순서대로 움직일게", "maze_hints_title_2": "장애물 뛰어넘기", "maze_hints_content_2": "장애물이 있으면 어떻게 해야하나요?", "maze_hints_detail_2": "길을 가다보면 장애물을 만날 수 있어.<br>장애물이 앞에 있을 때에는 뛰어넘기 블록을 사용해야 해.", "maze_hints_title_3": "반복 블록(1)", "maze_hints_content_3": "(3)회 반복하기 블록은 어떻게 사용하나요?", "maze_hints_detail_3": "같은 행동을 여러번 반복하려면 ~번 반복하기 블록을 사용해야 해.<br>반복하고 싶은 블록들을 ~번 반복하기 안에 넣고 반복 횟수를 입력하면 돼.", "maze_hints_title_4": "반복 블록(2)", "maze_hints_content_4": "~를 만날 때 까지 반복하기 블록은 어떻게 사용하나요?", "maze_hints_detail_4": "~까지 반복하기'를 사용하면 같은 행동을 언제까지 반복할지를 정해줄 수 있어.<br>반복하고 싶은 블록들을 ~까지 반복하기안에 넣으면 돼.<br>그러면 {이미지}와 같은 타일 위에 있는 경우 반복이 멈추게 될 거야.", "maze_hints_title_5": "만약 블록", "maze_hints_content_5": "만약 ~라면 블록은 어떻게 동작하나요?", "maze_hints_detail_5": "만약 앞에 {이미지}가 있다면' 블록을 사용하면 앞에 {이미지}가 있을 때 어떤 행동을 할 지 정해줄 수 있어.<br>앞에 {이미지}가 있을 때에만 블록 안의 블록들을 실행하고<br> 그렇지 않으면 실행하지 않게 되는 거야.", "maze_hints_title_6": "반복 블록(3)", "maze_hints_content_6": "모든 ~를 만날 때 까지 블록은 어떻게 동작하나요?", "maze_hints_detail_6": "모든 {타일}에 한 번씩 도착할 때까지 그 안에 있는 블록을 반복해서 실행해.<br>모든 {타일}에 한 번씩 도착하면 반복이 멈추게 될 거야.", "maze_hints_title_7": "특별 힌트", "maze_hints_content_7": "너무 어려워요. 도와주세요.", "maze_hints_detail_7": "내가 가야하는 길을 자세히 봐. 작은 사각형 4개가 보여?<br>작은 사각형을 도는 블록을 만들고, 반복하기를 사용해 보는것은 어때?", "maze_hints_title_8": "약속", "maze_hints_content_8": "약속하기/약속 불러오기 무엇인가요? 어떻게 사용하나요?", "maze_hints_detail_8": "나를 움직이기 위해 자주 쓰는 블록들의 묶음을 '약속하기' 블록 아래에 조립하여 약속으로 만들 수 있어.<br>한번 만들어 놓은 약속은 '약속 불러오기' 블록을 사용하여 여러 번 꺼내 쓸 수 있다구.", "ai_hints_title_1_1": "게임의 목표", "ai_hints_content_1_1": "돌을 피해 오른쪽 행성까지 안전하게 이동할 수 있도록 도와주세요.", "ai_hints_detail_1_1": "돌을 피해 오른쪽 행성까지 안전하게 이동할 수 있도록 도와주세요.", "ai_hints_title_1_2": "시작 방법", "ai_hints_content_1_2": "어떻게 시작할 수 있나요?", "ai_hints_detail_1_2": "1. 블록 꾸러미에서 원하는 블록을 꺼내어 “시작하기를 클릭했을 때” 블록과 연결해봐<br>2. 다 조립했으면, 시작을 눌러봐<br>3. 나는 네가 조립한 블록대로 위에서부터 순서대로 움직일게", "ai_hints_title_1_3": "움직이게 하기", "ai_hints_content_1_3": "엔트리봇은 어떻게 움직이나요?", "ai_hints_detail_1_3": "나는 위쪽으로 가거나 앞으로 가거나 아래쪽으로 갈 수 있어.<br>방향을 정할 때에는 돌이 없는 방향으로 안전하게 갈 수 있도록 해줘.<br>나를 화면 밖으로 내보내면 우주미아가 되어버리니 조심해!", "ai_hints_title_2_1": "게임의 목표", "ai_hints_content_2_1": "반복하기 블록으로 돌들을 피할 수 있도록 도와주세요.", "ai_hints_detail_2_1": "반복하기 블록으로 돌들을 피할 수 있도록 도와주세요.", "ai_hints_title_2_2": "반복 블록", "ai_hints_content_2_2": "반복 블록은 무슨 블록인가요?", "ai_hints_detail_2_2": "휴~ 이번에 가야 할 길은 너무 멀어서 하나씩 조립하기는 힘들겠는걸? 반복하기블록을 사용해봐.<br>똑같이 반복되는 블록들을 반복하기 블록으로 묶어주면 아주 긴 블록을 짧게 줄여줄 수 있어!", "ai_hints_content_3_1": "만약 블록으로 돌을 피할 수 있도록 도와주세요.", "ai_hints_title_3_2": "만약 블록(1)", "ai_hints_content_3_2": "만약 ~라면 블록은 어떻게 동작하나요?", "ai_hints_detail_3_2": "만약 앞에 ~가 있다면 / 아니면 블록을 사용하면 내 바로 앞에 돌이 있는지 없는지 확인해서 다르게 움직일 수 있어~<br>만약 내 바로 앞에 돌이 있다면 '만약' 아래에 있는 블록들을 실행하고 돌이 없으면 '아니면' 안에 있는 블록들을 실행할 거야.<br>내 바로 앞에 돌이 있을 때와 없을 때, 어떻게 움직일지 잘 결정해줘~", "ai_hints_content_4_1": "레이더의 사용 방법을 익히고 돌을 피해보세요.", "ai_hints_detail_4_1": "레이더의 사용 방법을 익히고 돌을 피해보세요.", "ai_hints_title_4_2": "레이더(1)", "ai_hints_content_4_2": "레이더란 무엇인가요? 어떻게 활용할 수 있나요?", "ai_hints_detail_4_2": "레이더는 지금 내가 물체와 얼마나 떨어져 있는지 알려주는 기계야.<br>만약 바로 내 앞에 무엇인가 있다면 앞쪽 레이더는 '1'을 보여줘.<br>또, 레이더는 혼자 있을 때 보다 만약 &lt;사실&gt;이라면 / 아니면 블록과<br> 같이 쓰이면 아주 강력하게 쓸 수 있어.<br>예를 들어 내 앞에 물체와의 거리가 1보다 크다면 나는 안전하게 앞으로 갈 수 있겠지만, 아니라면 위나 아래쪽으로 피하도록 할 수 있지.", "ai_hints_title_4_3": "만약 블록(2)", "ai_hints_content_4_3": "만약 <사실>이라면 블록은 어떻게 사용하나요?", "ai_hints_detail_4_3": "만약 &lt;사실&gt;이라면 / 아니면 블록은 &lt;사실&gt; 안에 있는 내용이 맞으면 '만약' 아래에 있는 블록을 실행하고, 아니면 '아니면' 아래에 있는 블록을 실행해.<br>어떤 상황에서 다르게 움직이고 싶은 지를 잘 생각해서 &lt;사실&gt; 안에 적절한 판단 조건을 만들어 넣어봐.<br>판단 조건을 만족해서 '만약' 아래에 있는 블록을 실행하고 나면 '아니면' 아래에 있는 블록들은 실행되지 않는다는 걸 기억해!", "ai_hints_content_5_1": "레이더를 활용해 돌을 쉽게 피할 수 있도록 도와주세요.", "ai_hints_detail_5_1": "레이더를 활용해 돌을 쉽게 피할 수 있도록 도와주세요.", "ai_hints_title_5_2": "만약 블록(3)", "ai_hints_content_5_2": "만약 블록이 겹쳐져 있으면 어떻게 동작하나요?", "ai_hints_detail_5_2": "만약 ~ / 아니면 블록안에도 만약 ~ / 아니면 블록을 넣을 수 있어! 이렇게 되면 다양한 상황에서 내가 어떻게 행동해야 할지 정할 수 있어.<br>예를 들어 앞에 돌이 길을 막고 있을때와 없을때의 행동을 정한다음, 돌이 있을때의 상황에서도 상황에 따라 위쪽으로 갈지 아래쪽으로 갈지 선택 할 수 있어", "ai_hints_title_6_1": "레이더(2)", "ai_hints_content_6_1": "위쪽 레이더와 아래쪽 레이더의 값을 비교하고 싶을 땐 어떻게 하나요?", "ai_hints_detail_6_1": "([위쪽]레이더) 블록은 위쪽 물체까지의 거리를 뜻하는 블록이야.<br>아래쪽과 위쪽 중에서 어느 쪽에 돌이 더 멀리 있는지 확인하기 위해서 쓸 수 있는 블록이지.<br>돌을 피해가는 길을 선택할 때에는 돌이 멀리 떨어져 있는 쪽으로 피하는게 앞으로 멀리 가는데 유리할거야~", "ai_hints_content_7_1": "아이템을 향해 이동하여 돌을 피해보세요.", "ai_hints_detail_7_1": "아이템을 향해 이동하여 돌을 피해보세요.", "ai_hints_title_7_2": "물체 이름 확인", "ai_hints_content_7_2": "앞으로 만날 물체의 이름을 확인해서 무엇을 할 수 있나요?", "ai_hints_detail_7_2": "아이템을 얻기위해서는 아이템이 어디에 있는지 확인할 필요가 있어. <br>그럴 때 사용할 수 있는 블록이 [위쪽] 물체는 [아이템]인가? 블록이야.<br>이 블록을 활용하면 아이템이 어느 위치에 있는지 알 수 있고 아이템이 있는 방향으로 움직이도록 블록을 조립할 수 있어.", "ai_hints_content_8_1": "아이템을 적절하게 사용해서 돌을 피해보세요.", "ai_hints_detail_8_1": "아이템을 적절하게 사용해서 돌을 피해보세요.", "ai_hints_title_8_2": "아이템", "ai_hints_content_8_2": "아이템은 어떻게 얻고 사용하나요?", "ai_hints_detail_8_2": "돌들을 이리저리 잘 피해 나가더라도 앞이 모두 돌들로 꽉 막혀있을 땐 빠져나갈 방법이 없겠지? 그럴 때에는 아이템사용 블럭을 사용해봐. <br>이 블록은 내 앞의 돌들을 모두 없애는 블록이야.<br>단, 아이템이 있어야지만 블록을 사용할 수 있고, 아이템은 이미지를 지나면 얻을 수 있어.", "ai_hints_content_9_1": "지금까지 배운 것들을 모두 활용해서 최대한 멀리 가보세요.", "ai_hints_detail_9_1": "지금까지 배운 것들을 모두 활용해서 최대한 멀리 가보세요.", "ai_hints_title_9_2": "그리고", "ai_hints_content_9_2": "그리고 블록은 어떻게 사용하나요?", "ai_hints_detail_9_2": "그리고 블록에는 여러개의 조건을 넣을 수 있어, 넣은 모든 조건이 사실일때만 사실이 되어 만약 블록 안에 있는 블록이 실행되고, 하나라도 거짓이 있으면 거짓으로 인식해서 그 안에 있는 블록을 실행하지 않아", "maze_text_goal_1": "move(); 명령어를 사용하여 부품 상자까지 나를 이동시켜줘!", "maze_text_goal_2": "jump(); 명령어로 장애물을 피해 부품 상자까지 나를 이동시켜줘!", "maze_text_goal_3": "left(); right(); 명령어로 부품상자까지 나를 이동시켜줘!", "maze_text_goal_4": "여러가지 명령어를 사용하여 부품상자까지 나를 이동시켜줘!", "maze_text_goal_5": "두 부품상자에 다 갈 수 있도록 나를 이동시켜줘!", "maze_text_goal_6": "두 부품상자에 다 갈 수 있도록 나를 이동시켜줘!", "maze_text_goal_7": "for 명령어를 사용하여 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_8": "for 명령어를 사용하고, 장애물을 피해 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_9": "while 명령어를 사용하여 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_10": "if와 while 명령어를 사용하여 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_11": "if와 while 명령어를 사용하여 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_12": "if와 while 명령어를 사용하여 친구가 있는 곳 까지 나를 이동시켜줘!", "maze_text_goal_13": "while과 for 명령어를 사용하여 모든 친구들을 만날 수 있도록 나를 이동시켜줘!", "maze_text_goal_14": "while과 for 명령어를 사용하여 모든 친구들을 만날 수 있도록 나를 이동시켜줘!", "maze_text_goal_15": "함수를 불러와서 배터리까지 나를 이동시켜줘!", "maze_text_goal_16": "함수에 명령어를 넣고 함수를 불러와서 배터리까지 나를 이동시켜줘!", "maze_text_goal_17": "함수에 명령어를 넣고 함수를 불러와서 배터리까지 나를 이동시켜줘!", "maze_text_goal_18": "함수에 명령어를 넣고 함수를 불러와서 배터리까지 나를 이동시켜줘!", "maze_text_goal_19": "함수에 명령어를 넣고 함수를 불러와서 배터리까지 나를 이동시켜줘!", "maze_text_goal_20": "함수와 다른명령어들을 섞어 사용하여 배터리까지 나를 이동시켜줘!", "maze_attack_range": "공격 가능 횟수", "maze_attack": "공격", "maze_attack_both_sides": "양 옆 공격", "above_radar": "위쪽 레이더", "above_radar_text_mode": "radar_up", "bottom_radar": "아래쪽 레이더", "bottom_radar_text_mode": "radar_down", "front_radar": "앞쪽 레이더", "front_radar_text_mode": "radar_right", "above_object": "위쪽 물체", "above_object_text_mode": "object_up", "front_object": "앞쪽 물체", "front_object_text_mode": "object_right", "below_object": "아래쪽 물체", "below_object_text_mode": "object_down", "destination": "목적지", "asteroids": "돌", "item": "아이템", "wall": "벽", "destination_text_mode": "destination", "asteroids_text_mode": "stone", "item_text_mode": "item", "wall_text_mode": "wall", "buy_now": "구매바로가기", "goals": "목표", "instructions": "이용 안내", "object_info": "오브젝트 정보", "entry_basic_mission": "엔트리 기본 미션", "entry_application_mission": "엔트리 응용 미션", "maze_move_forward": "앞으로 한 칸 이동", "maze_when_run": "시작하기를 클릭했을때", "maze_turn_left": "왼쪽으로 회전", "maze_turn_right": "오른쪽으로 회전", "maze_repeat_times_1": "", "maze_repeat_times_2": "번 반복하기", "maze_repeat_until_1": "", "maze_repeat_until_2": "을 만날때까지 반복", "maze_call_function": "약속 불러오기", "maze_function": "약속하기", "maze_repeat_until_all_1": "모든", "maze_repeat_until_all_2": "만날 때 까지 반복", "command_guide": "명령어 도움말", "ai_success_msg_1": "덕분에 무사히 지구에 도착할 수 있었어! 고마워!", "ai_success_msg_2": "다행이야! 덕분에", "ai_success_msg_3": "번 만큼 앞쪽으로 갈 수 있어서 지구에 구조 신호를 보냈어! 이제 지구에서 구조대가 올거야! 고마워!", "ai_success_msg_4": "좋았어!", "ai_cause_msg_1": "이런, 어떻게 움직여야 할 지 더 말해줄래?", "ai_cause_msg_2": "아이쿠! 정말로 위험했어! 다시 도전해보자", "ai_cause_msg_3": "우와왓! 가야할 길에서 벗어나버리면 우주 미아가 되버릴꺼야. 다시 도전해보자", "ai_cause_msg_4": "너무 복잡해, 이 블록을 써서 움직여볼래?", "ai_move_forward": "앞으로 가기", "ai_move_above": "위쪽으로 가기", "ai_move_under": "아래쪽으로 가기", "ai_repeat_until_dest": "목적지에 도달 할 때까지 반복하기", "ai_if_front_1": "만약 앞에", "ai_if_front_2": "가 있다면", "ai_else": "아니면", "ai_if_1": "만약", "ai_if_2": "이라면", "ai_use_item": "아이템 사용", "ai_radar": "레이더", "ai_above": "위쪽", "ai_front": "앞쪽", "ai_under": "아래쪽", "ai_object_is_1": "", "ai_object_is_2": "물체는", "challengeMission": "다른 미션 도전하기", "nextMission": "다음 미션 도전하기", "withTeacher": "함께 만든 선생님들", "host": "주최", "support": "후원", "subjectivity": "주관", "learnMore": " 더 배우고 싶어요", "ai_object_is_3": "인가?", "stage_is_not_available": "아직 진행할 수 없는 스테이지입니다. 순서대로 스테이지를 진행해 주세요.", "progress_not_saved": "진행상황이 저장되지 않습니다.", "want_refresh": "이 페이지를 새로고침 하시겠습니까?", "monthly_entry_grade": "초등학교 3학년 ~ 중학교 3학년", "monthly_entry_contents": "매월 발간되는 월간엔트리와 함께 소프트웨어 교육을 시작해 보세요! 차근차근 따라하며 쉽게 익힐 수 있도록 가볍게 구성되어있습니다. 기본, 응용 콘텐츠와 더 나아가기까지! 매월 업데이트되는 8개의 콘텐츠와 교재를 만나보세요~", "monthly_entry_etc1": "*메인 페이지의 월간 엔트리 추천코스를 활용하면 더욱 쉽게 수업을 할 수 있습니다.", "monthly_entry_etc2": "*월간엔트리는 학기 중에만 발간됩니다.", "group_make_lecture_1": "내가 만든 강의가 없습니다.", "group_make_lecture_2": "'만들기>오픈 강의 만들기'에서", "group_make_lecture_3": "우리반 학습내용에 추가하고 싶은 강의를 만들어 주세요.", "group_make_lecture_4": "강의 만들기", "group_add_lecture_1": "관심 강의가 없습니다.", "group_add_lecture_2": "'학습하기>오픈 강의> 강의'에서 우리반 학습내용에", "group_add_lecture_3": "추가하고 싶은 강의를 관심강의로 등록해 주세요.", "group_add_lecture_4": "강의 보기", "group_make_course_1": "내가 만든 강의 모음이 없습니다.", "group_make_course_2": "'만들기 > 오픈 강의 만들기> 강의 모음 만들기'에서", "group_make_course_3": "학습내용에 추가하고 싶은 강의 모음을 만들어 주세요.", "group_make_course_4": "강의 모음 만들기", "group_add_course_1": "관심 강의 모음이 없습니다.", "group_add_course_2": "'학습하기 > 오픈 강의 > 강의 모음'에서 우리반 학습내용에", "group_add_course_3": "추가하고 싶은 강의 모음을 관심 강의 모음으로 등록해 주세요.", "group_add_course_4": "강의 모음 보기", "hw_main_title": "프로그램 다운로드", "hw_desc_wrapper": "엔트리 하드웨어 연결 프로그램과 오프라인 버전이 \n서비스를 한층 더 강화해 업그레이드 되었습니다.\n업데이트 된 프로그램을 설치해주세요!", "hw_downolad_link": "하드웨어 연결 \n프로그램 다운로드", "save_as_image_all": "모든 코드 이미지로 저장하기", "save_as_image": "이미지로 저장하기", "maze_perfect_success": "멋져! 완벽하게 성공했어~", "maze_success_many_block_1": "좋아", "maze_fail_obstacle_remain": "친구들이 다치지 않도록 모든 <span class='bitmap_obstacle_spider'></span>을 없애줘.", "maze_fail_item_remain": "샐리 공주를 구하기 위해 모든 미네랄을 모아 와줘.", "maple_fail_item_remain": "음식을 다 먹지 못해서 힘이 나지 않아. 모든 음식을 다 먹을 수 있도록 도와줘.", "maze_fail_not_found_destory_object": "아무것도 없는 곳에 능력을 낭비하면 안 돼!", "maze_fail_not_found_destory_monster": "몬스터가 없는 곳에 공격을 하면 안 돼!", "maple_fail_not_found_destory_monster": "공격 블록은 몬스터가 있을 때에만 해야 돼!", "maze_fail_more_move": "목적지까지는 좀 더 움직여야 해!", "maze_fail_wall_crash": "으앗! 거긴 갈 수 없는 곳이야!", "maze_fail_contact_brick": "에구구… 부딪혔다!", "maze_fail_contact_iron1": "으앗! 장애물에 부딪혀버렸어", "maze_fail_contact_iron2": "으앗! 장애물이 떨어져서 다쳐버렸어. 장애물이 내려오기전에 움직여줘..", "maze_fail_fall_hole": "앗, 함정에 빠져 버렸어...", "maze_fail_hit_unit": "몬스터에게 당해버렸어! 위험한 몬스터를 물리치기 위해 하트 날리기 블록을 사용해줘!", "maze_fail_hit_unit2": "윽, 몬스터에게 공격당했다! 두 칸 떨어진 곳에서 공격해줘!", "maze_fail_hit_unit_by_mushroom": "주황버섯에게 당해버렸어!<br /><img src='/img/assets/maze/icon/mushroom.png' /> 공격하기 블록을 사용해서 나쁜 몬스터를 혼내줘!", "maze_fail_hit_unit_by_lupin": "루팡에게 당해버렸어!<br /><img src='/img/assets/maze/icon/lupin.png' /> 공격하기 블록을 두 칸 떨어진 곳에서 사용해서 나쁜 몬스터를 혼내줘!", "maze_fail_elnath_fail": "으앗! 나쁜 몬스터가 나를 공격했어.<br/>나쁜 몬스터가 나에게 다가오지 못하게 혼내줘!", "maze_fail_pepe": "", "maze_fail_yeti": "그 몬스터는 너무 강해서 <img width='24px' src='/img/assets/week/blocks/yeti.png'/> 공격하기 블록으로는 혼내줄 수 없어<br/><img width='24px' src='/img/assets/week/blocks/bigYeti.png'/> 공격하기 블록을 사용해보자.", "maze_fail_peti": "그 몬스터에게 <img width='24px' src='/img/assets/week/blocks/bigYeti.png'/> 공격하기 블록을 사용하면,<br/>강한 몬스터인 <img width='24px' src='/img/assets/week/blocks/bigYeti.png'/>가 나왔을 때 혼내줄 수 없어<br/><img width='24px' src='/img/assets/week/blocks/yeti.png'/> 공격하기 블록을 사용해보자.", "maze_fail_both_side": "양 옆 공격하기는 양쪽에 몬스터가 있을 때에만 사용해야 돼!", "maze_wrong_attack_obstacle": "이 곳에서는 <img src='/img/assets/maze/icon/lupin.png' /> 공격하기 블록을 사용할 수 없어<br/>주황 버섯에게는 <img src='/img/assets/maze/icon/mushroom.png' /> 공격하기 블록을 사용해보자.", "maze_fail_contact_spider": "거미집에 걸려 움직일 수가 없어...", "maze_success_perfect": "멋져! 완벽하게 성공했어~", "maze_success_block_excess": "좋아! %1개의 블록을 사용해서 성공했어! <br> 하지만, %2개의 블록만으로 성공하는 방법도 있어. 다시 도전해 보는 건 어때?", "maze_success_not_essential": "좋아! %1개의 블록을 사용해서 성공했어! <br>하지만 이 블록을 사용하면 더 쉽게 해결할 수 있어. 다시 도전해 보는 건 어때?", "maze_success_final_perfect_basic": "좋아! 샐리 공주가 어디 있는지 찾았어! 이제 샐리 공주를 구할 수 있을 거야!", "maze_success_final_block_excess_basic": "좋아! 샐리 공주가 어디 있는지 찾았어! 이제 샐리 공주를 구할 수 있을 거야!%1개의 블록을 사용했는데, %2개의 블록만으로 성공하는 방법도 있어. 다시 해볼래?", "maze_success_final_perfect_advanced": "샐리 공주가 있는 곳까지 도착했어! 이제 악당 메피스토를 물리치고 샐리를 구하면 돼!", "maze_success_final_block_excess_advanced": "샐리 공주가 있는 곳까지 도착했어! 이제 악당 메피스토를 물리치고 샐리를 구하면 돼!%1개의 블록을 사용했는데, %2개의 블록만으로 성공하는 방법도 있어. 다시 해볼래?", "maze_success_final_distance": "좋아! 드디어 우리가 샐리 공주를 무사히 구해냈어. 구할 수 있도록 도와줘서 정말 고마워!<br>%1칸 움직였는데 다시 한 번 다시해서 60칸까지 가볼래?", "maze_success_final_perfect_ai": "좋았어! 드디어 우리가 샐리 공주를 무사히 구해냈어. 구할 수 있도록 도와줘서 정말 고마워!", "maple_success_perfect": "좋아! 완벽하게 성공했어!!", "maple_success_block_excess": "좋아! %1개의 블록을 사용해서 성공했어! <br> 그런데 %2개의 블록으로도 성공하는 방법이 있어. 다시 도전해 보는건 어때?", "maple_success_not_essential": "좋아! %1개의 블록을 사용해서 성공했어! <br>그런데 이 블록을 사용하면 더 쉽게 해결할 수 있어. 다시 도전해 보는 건 어때?", "maple_success_final_perfect_henesys": "멋져! 헤네시스 모험을 훌륭하게 해냈어.", "maple_success_final_perfect_excess_henesys": "멋져! 헤네시스 모험을 잘 해냈어.<br />그런데 %2개의 블록으로도 성공하는 방법이 있어. 다시 도전해 보는 건 어때?", "maple_success_final_not_essential_henesys": "멋져! 헤네시스 모험을 잘 해냈어.<br />그런데 이 블록을 사용하면 더 쉽게 해결할 수 있어. 다시 도전해 보는 건 어때?", "maple_success_final_perfect_ellinia": "우와! 이 곳에서 정말 재밌는 모험을 했어!<br/>다음 모험도 같이 할거지? ", "maple_success_final_perfect_excess_ellinia": "우와! 이 곳에서 정말 재밌는 모험을 했어!<br />그런데 %2개의 블록으로도 성공하는 방법이 있어. 다시 도전해 보는 건 어때?", "maple_success_final_not_essential_ellinia": "우와! 이 곳에서 정말 재밌는 모험을 했어!<br />그런데 이 블록을 사용하면 더 쉽게 해결할 수 있어. 다시 도전해 보는 건 어때?", "maple_fail_fall_hole": "으앗! 빠져버렸어!<br />뛰어넘기 블록을 사용해서 건너가보자.", "maple_fail_ladder_fall_hole": "으앗! 빠져버렸어!<br />사다리 타기 블록을 사용해서 다른 길로 가보자.", "maple_fail_more_move": "성공하려면 목적지까지 조금 더 움직여야 해!", "maple_fail_not_found_ladder": "이런, 여기엔 탈 수 있는 사다리가 없어.<br />사다리 타기 블록은 사다리가 있는 곳에서만 사용 해야해.", "maple_fail_not_found_meat": "이런, 여기엔 먹을 수 있는 음식이 없어!<br />음식 먹기 블록은 음식이 있는 곳에서만 사용 해야해.", "maple_cert_input_title": "내가 받을 인증서에 적힐 이름은?", "maze_distance1": "거리 1", "maze_distance2": "거리 2", "maze_distance3": "거리 3", "ev3": "EV3", "roduino": "로두이노", "schoolkit": "스쿨키트", "smartboard": "과학상자 코딩보드", "codestar": "코드스타", "cobl": "코블", "block_coding": "블록코딩", "python_coding": "엔트리파이선", "dadublock": "다두블럭", "dadublock_car": "다두블럭 자동차", "blacksmith": "대장장이 보드", "course_submit_homework": "과제 제출", "course_done_study": "학습 완료", "course_show_list": "목록", "modi": "모디", "chocopi": "초코파이보드", "coconut": "코코넛", "jdkit": "제이디키트", "jdcode": "제이디코드", "practical_course": "교과용 만들기", "entry_scholarship_title": "엔트리 학술 자료", "entry_scholarship_content": "엔트리는 대학/학회 등과 함께 다양한 연구를 진행하여 전문성을 강화해나가고 있습니다. 엔트리에서 제공하는 연구용 자료를 확인해보세요", "entry_scholarship_content_sub": "*엔트리에서 제공하는 데이터는 연구 및 분석에 활용될 수 있도록 온라인코딩파티에 참여한 사용자들이 미션을 해결하는 일련의 과정을 로그 형태로 저장한 데이터 입니다.", "entry_scholarship_download": "자료 다운로드", "codingparty_2016_title": "2016 온라인 코딩파티", "codingparty_2016_content": "미션에 참여한 사용자들의 블록 조립 순서, 성공/실패 유무가 학년, 성별 정보와 함께 제공됩니다.", "scholarship_go_mission": "미션 확인하기", "scholarship_guide": "자료 활용 방법", "scholarship_see_guide": "가이드 보기", "scholarship_guide_desc": "연구용 자료를 읽고 활용할 수 있는 방법이 담긴 개발 가이드 입니다. ", "scholarship_example": "자료 활용 예시", "scholarship_example_desc": "연구용 자료를 활용하여 발표된 논문을 확인 할 수 있습니다.", "scholarship_see_example": "논문 다운로드", "Altino": "알티노", "private_project": "비공개 작품입니다.", "learn_programming_entry_mission": "\"엔트리봇\"과 함께 미션 해결하기", "learn_programming_line_mission": "\"라인레인저스\"와 샐리구하기", "learn_programming_choseok": "\"마음의 소리\"의 조석과 게임 만들기", "learn_programming_maple": "\"핑크빈\"과 함께 신나는 메이플 월드로!", "learn_programming_level_novice": "기초", "learn_programming_level_inter": "중급", "learn_programming_level_advanced": "고급", "line_look_for": "샐리를 찾아서", "line_look_for_desc_1": "라인 레인저스의 힘을 모아 강력한 악당 메피스토를 물리치고 샐리를 구해주세요!", "line_save": "샐리 구하기", "line_save_desc_1": "메피스토 기지에 갇힌 샐리. 라인 레인저스가 장애물을 피해 샐리를 찾아갈 수 있도록 도와주세요!", "line_escape": "샐리와 탈출하기", "line_escape_desc_1": "폭파되고 있는 메피스토 기지에서 샐리와 라인 레인저스가 무사히 탈출할 수 있도록 도와주세요!", "solve_choseok": "가위바위보 만들기", "solve_choseok_desc_1": "만화 속 조석이 가위바위보 게임을 만들 수 있도록 도와주세요!", "solve_henesys": "헤네시스", "solve_ellinia": "엘리니아", "solve_elnath": "엘나스", "solve_henesys_desc_1": "마을을 모험하며, 배고픈 핑크빈이 음식을 배불리 먹을 수 있도록 도와주세요!", "solve_ellinia_desc_1": "숲 속을 탐험하며, 나쁜 몬스터들을 혼내주고 친구 몬스터들을 구해주세요!", "solve_elnath_desc_1": "나쁜 몬스터가 점령한 설산을 지나, 새로운 모험을 시작할 수 있는 또 다른 포털을 찾아 떠나보세요 !", "save_modified_shape": "수정된 내용을 저장하시겠습니까?", "attach_file": "첨부", "enter_discuss_title": "제목을 입력해 주세요(40자 이하)", "enter_discuss_title_alert": "제목을 입력해 주세요", "discuss_upload_warn": "10MB이하의 파일을 올려주세요.", "discuss_list": "목록보기", "discuss_write_notice": "우리반 공지사항으로 지정하여 게시판 최상단에 노출합니다.", "discuss_write_notice_open": "공지사항으로 지정하여 게시판 최상단에 노출합니다.", "search_전체": "전체", "search_게임": "게임", "search_애니메이션": "애니메이션", "search_미디어아트": "미디어 아트", "search_피지컬": "피지컬", "search_기타": "기타", "discuss_write_textarea_placeholer": "내용을 입력해 주세요(10000자 이하)", "maze_road": "길", "account_deletion": "회원탈퇴", "bug_report_too_many_request": "신고 내용이 전송 되고 있습니다. 잠시 후에 다시 시도해주시길 바랍니다.", "pinkbean_index_title": "핑크빈과 함께 신나는 메이플 월드로!", "pinkbean_index_content": "심심함을 참지 못한 핑크빈이 메이플 월드로 모험을 떠났습니다.<br />핑크빈과 함께 신나는 메이플 월드를 탐험하여 모험일지를 채워주세요.<br />각 단계를 통과하면서 자연스럽게 소프트웨어를 배워볼 수 있고, 미션을 마치면 인증서도 얻을 수 있습니다.", "rangers_index_title": "라인 레인저스와 함께 샐리를 구하러 출동!", "rangers_index_content": "악당 메피스토에게 납치된 샐리를 구하기 위해 라인 레인저스가 뭉쳤습니다.<br />소프트웨어의 원리를 통해 장애물을 극복하고, 샐리를 구출하는 영웅이 되어주세요.<br />각 단계를 통과하면서 자연스럽게 소프트웨어를 배워볼 수 있고, 미션을 마치면 인증서도<br />얻을 수 있습니다.", "rangers_replay_button": "영상 다시보기", "rangers_start_button": "미션 시작", "bug_report_title": "버그 리포트", "bug_report_content": "이용 시 발생하는 오류나 버그 신고 및 엔트리를 위한 좋은 제안을 해주세요." }; Lang.Msgs = { "monthly_intro_0": "<월간 엔트리>는 소프트웨어 교육에 익숙하지 않은 선생님들도 쉽고 재미있게 소프트웨어 교육을 하실 수 있도록 만들어진 ", "monthly_intro_1": "SW교육 잡지입니다. 재미있는 학습만화와 함께 하는 SW 교육 컨텐츠를 만나보세요!", "monthly_title_0": "강아지 산책시키기 / 선대칭 도형 그리기", "monthly_title_1": "동영상의 원리 / 음악플레이어 만들기", "monthly_title_2": "대한민국 지도 퍼즐 / 벚꽃 애니메이션", "monthly_title_3": "마우스 졸졸, 물고기 떼 / 태양계 행성", "monthly_title_4": "감자 캐기 / 딸기 우유의 진하기", "monthly_description_0": "키보드 입력에 따라 움직이는 강아지와 신호와 좌표를 통해 도형을 그리는 작품을 만들어 봅시다.", "monthly_description_1": "변수를 활용하여 사진 영상 작품과 음악 플레이어 작품을 만들어 봅시다.", "monthly_description_2": "~인 동안 반복하기를 이용한 퍼즐 게임과 복제본, 무작위 수를 이용한 애니메이션 작품을 만들어 봅시다.", "monthly_description_3": "계속 반복하기 블록과 수학 연산 블록을 활용하여 물고기 미디어 아트 작품과 태양계를 만들어 봅시다.", "monthly_description_4": "신호와 변수, 수학 연산 블록을 활용하여 감자 캐기 작품과 딸기 우유 만들기 작품을 만들어 봅시다.", "save_canvas_alert": "저장 중입니다.", "feedback_too_many_post": "신고하신 내용이 전송되고 있습니다. 10초 뒤에 다시 시도해주세요.", "usable_object": "사용가능 오브젝트", "shared_varaible": "공유 변수", "invalid_url": "영상 주소를 다시 확인해 주세요.", "auth_only": "인증된 사용자만 이용이 가능합니다.", "runtime_error": "실행 오류", "to_be_continue": "준비 중입니다.", "warn": "경고", "error_occured": "다시 한번 시도해 주세요. 만약 같은 문제가 다시 발생 하면 '제안 및 건의' 게시판에 문의 바랍니다. ", "error_forbidden": "저장할 수 있는 권한이 없습니다. 만약 같은 문제가 다시 발생 하면 '제안 및 건의' 게시판에 문의 바랍니다. ", "list_can_not_space": "리스트의 이름은 빈 칸이 될 수 없습니다.", "sign_can_not_space": "신호의 이름은 빈 칸이 될 수 없습니다.", "variable_can_not_space": "변수의 이름은 빈 칸이 될 수 없습니다.", "training_top_title": "연수 프로그램", "training_top_desc": "엔트리 연수 지원 프로그램을 안내해 드립니다.", "training_main_title01": "선생님을 위한 강사 연결 프로그램", "training_target01": "교육 대상 l 선생님", "training_sub_title01": "“우리 교실에 SW날개를 달자”", "training_desc01": "소프트웨어(SW) 교원 연수가 필요한 학교인가요?\nSW 교원 연수가 필요한 학교에 SW교육 전문 선생님(고투티처) 또는 전문 강사를 연결해드립니다.", "training_etc_ment01": "* 강의비 등 연수 비용은 학교에서 지원해주셔야합니다.", "training_main_title02": "소프트웨어(SW) 선도학교로 찾아가는 교원연수", "training_target02": "교육 대상 l SW 선도, 연구학교", "training_sub_title02": "“찾아가, 나누고, 이어가다”", "training_desc02": "SW 교원 연수를 신청한 선도학교를 무작위로 추첨하여 상반기(4,5,6월)와\n하반기(9,10,11월)에 각 지역의 SW교육 전문 선생님(고투티처)께서 알차고\n재미있는 SW 기초 연수 진행 및 풍부한 교육사례를 공유하기 위해 찾아갑니다.", "training_etc_ment02": "", "training_main_title03": "학부모와 학생을 위한 연결 프로그램", "training_target03": "교육 대상 l 학부모, 학생", "training_sub_title03": "“SW를 더 가까이 만나는 시간”", "training_desc03": "학부모와 학생들을 대상으로 소프트웨어(SW) 연수가 필요한 학교에 각 지역의 SW교육 전문 선생님(고투티처) 또는 전문 강사를 연결해드립니다.", "training_etc_ment03": "* 강의비 등 연수 비용은 학교에서 지원해주셔야합니다.", "training_apply": "신청하기", "training_ready": "준비중입니다.", "new_version_title": "최신 버전 설치 안내", "new_version_text1": "하드웨어 연결 프로그램이", "new_version_text2": "<strong>최신 버전</strong>이 아닙니다.", "new_version_text3": "서비스를 한층 더 강화해 업데이트 된", "new_version_text4": "최신 버전의 연결 프로그램을 설치해 주세요.", "new_version_download": "최신 버전 다운로드<span class='download_icon'></span>", "not_install_title": "미설치 안내", "hw_download_text1": "하드웨어 연결을 위해서", "hw_download_text2": "<strong>하드웨어 연결 프로그램</strong>을 설치해 주세요.", "hw_download_text3": "하드웨어 연결 프로그램이 설치되어 있지 않습니다.", "hw_download_text4": "최신 버전의 연결 프로그램을 설치해 주세요.", "hw_download_btn": "연결 프로그램 다운로드<span class='download_icon'></span>", "not_support_browser": "지원하지 않는 브라우저입니다.", "quiz_complete1": "퀴즈 풀기 완료!", "quiz_complete2": "총 {0}문제 중에 {1}문제를 맞췄습니다.", "quiz_incorrect": "이런 다시 한 번 생각해보자", "quiz_correct": "정답이야!", "hw_connection_success": "하드웨어 연결 성공", "hw_connection_success_desc": "하드웨어 아이콘을 더블클릭하면, 센서값만 확인할 수 있습니다.", "hw_connection_success_desc2": "하드웨어와 정상적으로 연결되었습니다.", "ie_page_title": "이 브라우저는<br/>지원하지 않습니다.", "ie_page_desc": "엔트리는 인터넷 익스플로어 10 버전 이상 또는 크롬 브라우저에서 이용하실 수 있습니다.<br/>윈도우 업데이트를 진행하시거나, 크롬 브라우저를 설치해주세요.<br/>엔트리 오프라인 버전은 인터넷이 연결되어 있지 않아도 사용할 수 있습니다. 지금 다운받아서 시작해보세요!", "ie_page_chrome_download": "크롬 브라우저<br/>다운로드", "ie_page_windows_update": "윈도우 최신버전<br>업데이트", "ie_page_offline_32bit_download": "엔트리 오프라인 32bit<br>다운로드", "ie_page_offline_64bit_download": "엔트리 오프라인 64bit<br>다운로드", "ie_page_offline_mac_download": "엔트리 오프라인<br>다운로드", "cancel_deletion_your_account": "$1님의<br />회원탈퇴 신청을 취소하시겠습니까?", "account_deletion_canceled_complete": "회원탈퇴 신청이 취소되었습니다.", "journal_henesys_no1_title": "헤네시스 첫번째 모험일지", "journal_henesys_no2_title": "헤네시스 두번째 모험일지", "journal_henesys_no1_content": "헤네시스에서 첫 번째 모험 일지야. 오늘 헤네시스 터줏대감이라는 대장장이 집에 가려고 점프를 하다가 떨어질 뻔했어. 그 아저씨는 집 마당 앞에 왜 그렇게 구멍을 크게 만들어 놓는 거지? 나같이 대단한 몬스터가 아니고서야 이런 구멍을 뛰어넘을 수 있는 애들은 없을 거 같은데! 여하튼 정보도 얻었으니 아저씨가 추천한 맛 집으로 가볼까?", "journal_henesys_no2_content": "진짜 과식했다. 특히 그 식당의 고기는 정말 맛있었어. 어떻게 그렇게 부드럽게 만들었을까! 그렇지만 그 옆집 빵은 별로였어. 보니까 주방장 아저씨가 요리 수련을 한답시고 맨날 놀러 다니는 거 같더라고. 그럴 시간에 빵 하나라도 더 만들어 보는 게 나을 텐데. 후 이제 배도 채웠으니 본격적인 모험을 시작해볼까!", "journal_ellinia_no1_title": "엘리니아 첫번째 모험일지", "journal_ellinia_no2_title": "엘리니아 두번째 모험일지", "journal_ellinia_no1_content": "휴, 모르고 주황버섯을 깔고 앉아버렸지 뭐야. 걔네가 화날만 하지.. 그래도 그렇게 나에게 다같이 몰려들어 공격할 건 뭐람! 정말 무서운 놈들이야. 슬라임들이 힘들어 할만했어. 하지만 이 핑크빈님께서 다 혼내주었으니깐 걱정 없어. 이제 슬라임들이 친구가 되어주었으니 더욱 신나게 멋진 숲으로 모험을 이어가볼까.", "journal_ellinia_no2_content": "모험하면서 만난 친구 로얄패어리가 요즘 엘나스에 흉흉한 소문이 돈다고 했는데, 그게 뭘까? 오늘밤에 친구들이랑 집에서 놀기로 했는데 그때 물어봐야겠어. 완전 궁금한걸! 그런데 뭘 입고 가야하나.. 살이 너무쪄서 입을만 한게 없을거같은데.. 뭐 나는 늘 귀여우니까 어떤걸 입고가도 다들 좋아해줄거라구!", "journal_elnath_no1_title": "엘나스 첫번째 모험일지", "journal_elnath_no2_title": "엘나스 두번째 모험일지", "journal_elnath_no1_content": "세상에! 이게 말로만 듣던 눈인가? 내가 사는 마을은 항상 봄이여서 눈은 처음 봤어. 몬스터들을 혼내주느라 제대로 구경을 못했는데 지금보니 온세상이 이렇게나 하얗고 차갑다니 놀라워! 푹신 푹신하고 반짝거리는게 맛있어 보였는데 맛은 특별히 없네. 그런데 왠지 달콤한 초코 시럽을 뿌려먹으면 맛있을 거 같아. 조금 들고가고 싶은데 방법이 없다니 너무 아쉬운걸.", "journal_elnath_no2_content": "에퉤퉤, 실수로 석탄가루를 먹어버렸네. 나쁜 몬스터들! 도망가려면 조용히 도망갈 것이지 석탄을 잔뜩 뿌리면서 도망가버렸어. 덕분에 내 윤기나고 포송포송한 핑크색 피부가 갈수록 더러워지고 있잖아. 어서 여기를 나가서 깨끗하게 목욕부터 해야겠어. 아무리 모험이 좋다지만 이렇게 더럽게 돌아다니는 건 이 핑크빈님 자존심이 허락하지 않지.", "bug_report_alert_msg": "소중한 의견 감사합니다.", "version_update_msg1": "엔트리 오프라인 새 버전(%1)을 사용하실 수 있습니다.", "version_update_msg2": "엔트리 하드웨어 새 버전(%1)을 사용하실 수 있습니다.", "version_update_msg3": "지금 업데이트 하시겠습니까?" }; Lang.Users = { "auth_failed": "인증에 실패하였습니다", "birth_year": "태어난 해", "birth_year_before_1990": "1990년 이전", "edit_personal": "정보수정", "email": "이메일", "email_desc": "새 소식이나 정보를 받을 수 있 이메일 주소", "email_inuse": "이미 등록된 메일주소 입니다", "email_match": "이메일 주소를 올바르게 입력해 주세요", "forgot_password": "암호를 잊으셨습니까?", "job": "직업", "language": "언어", "name": "이름", "name_desc": "사이트내에서 표현될 이름 또는 별명", "name_not_empty": "이름을 반드시 입력하세요", "password": "암호", "password_desc": "최소 4자이상 영문자와 숫자, 특수문자", "password_invalid": "암호가 틀렸습니다", "password_long": "암호는 4~20자 사이의 영문자와 숫자, 특수문자로 입력해 주세요", "password_required": "암호는 필수입력 항목입니다", "project_list": "작품 조회", "regist": "가입 완료", "rememberme": "자동 로그인", "repeat_password": "암호 확인", "repeat_password_desc": "암호를 한번더 입력해 주세요", "repeat_password_not_match": "암호가 일치하지 않습니다", "sex": "성별", "signup_required_for_save": "저장을 하려면 로그인이 필요합니다.", "username": "아이디", "username_desc": "로그인시 사용할 아이디", "username_inuse": "이미 사용중인 아이디 입니다", "username_long": "아이디는 4~20자 사이의 영문자로 입력해 주세요", "username_unknown": "존재하지 않는 사용자 입니다", "already_verified": "이미 인증된 메일 주소입니다.", "email_address_unavailable": "유효하지 않은 인증 메일입니다.", "verification_complete": "이메일 주소가 인증되었습니다." }; Lang.Workspace = { "SaveWithPicture": "저장되지 않은 그림이 있습니다. 저장하시겠습니까?", "RecursiveCallWarningTitle": "함수 호출 제한", "RecursiveCallWarningContent": "한 번에 너무 많은 함수가 호출되었습니다. 함수의 호출 횟수를 줄여주세요.", "SelectShape": "이동", "SelectCut": "자르기", "Pencil": "펜", "Line": "직선", "Rectangle": "사각형", "Ellipse": "원", "Text": "글상자", "Fill": "채우기", "Eraser": "지우기", "Magnifier": "확대/축소", "block_helper": "블록 도움말", "new_project": "새 프로젝트", "add_object": "오브젝트 추가하기", "all": "전체", "animal": "동물", "arduino_entry": "아두이노 연결 프로그램", "arduino_program": "아두이노 프로그램", "arduino_sample": "엔트리 연결블록", "arduino_driver": "아두이노 드라이버", "cannot_add_object": "실행중에는 오브젝트를 추가할 수 없습니다.", "cannot_add_picture": "실행중에는 모양을 추가할 수 없습니다.", "cannot_add_sound": "실행중에는 소리를 추가할 수 없습니다.", "cannot_edit_click_to_stop": "실행중에는 수정할 수 없습니다.\n클릭하여 정지하기.", "cannot_open_private_project": "비공개 작품은 불러올 수 없습니다. 홈으로 이동합니다.", "cannot_save_running_project": "실행 중에는 저장할 수 없습니다.", "character_gen": "캐릭터 만들기", "check_runtime_error": "빨간색으로 표시된 블록을 확인해 주세요.", "context_download": "PC에 저장", "context_duplicate": "복제", "context_remove": "삭제", "context_rename": "이름 수정", "coordinate": "좌표", "create_function": "함수 만들기", "direction": "이동 방향", "drawing": "직접 그리기", "enter_list_name": "새로운 리스트의 이름을 입력하세요(10글자 이하)", "enter_name": "새로운 이름을 입력하세요", "enter_new_message": "새로운 신호의 이름을 입력하세요.", "enter_variable_name": "새로운 변수의 이름을 입력하세요(10글자 이하)", "family": "엔트리봇 가족", "fantasy": "판타지/기타", "file_new": "새로 만들기", "file_open": "온라인 작품 불러오기", "file_upload": "오프라인 작품 불러오기", "file_upload_login_check_msg": "오프라인 작품을 불러오기 위해서는 로그인을 해야 합니다.", "file_save": "저장하기", "file_save_as": "복사본으로 저장하기", "file_save_download": "내 컴퓨터에 저장하기", "func": "함수", "function_create": "함수 만들기", "function_add": "함수 추가", "interface": "인터페이스", "landscape": "배경", "list": "리스트", "list_add_calcel": "리스트 추가 취소", "list_add_calcel_msg": "리스트 추가를 취소하였습니다.", "list_add_fail": "리스트 추가 실패", "list_add_fail_msg1": "같은 이름의 리스트가 이미 존재합니다.", "list_add_fail_msg2": "리스트의 이름이 적절하지 않습니다.", "list_add_ok": "리스트 추가 완료", "list_add_ok_msg": "을(를) 추가하였습니다.", "list_create": "리스트 추가", "list_dup": "같은 이름의 리스트가 이미 존재합니다.", "list_newname": "새로운 이름", "list_remove": "리스트 삭제", "list_rename": "리스트 이름 변경", "list_rename_failed": "리스트 이름 변경 실패", "list_rename_ok": "리스트의 이름이 성공적으로 변경 되었습니다.", "list_too_long": "리스트의 이름이 너무 깁니다.", "message": "신호", "message_add_cancel": "신호 추가 취소", "message_add_cancel_msg": "신호 추가를 취소하였습니다.", "message_add_fail": "신호 추가 실패", "message_add_fail_msg": "같은 이름의 신호가 이미 존재합니다.", "message_add_ok": "신호 추가 완료", "message_add_ok_msg": "을(를) 추가하였습니다.", "message_create": "신호 추가", "message_dup": "같은 이름의 신호가 이미 존재합니다.", "message_remove": "신호 삭제", "message_remove_canceled": "신호 삭제를 취소하였습니다.", "message_rename": "신호 이름을 변경하였습니다.", "message_rename_failed": "신호 이름 변경에 실패하였습니다. ", "message_rename_ok": "신호의 이름이 성공적으로 변경 되었습니다.", "message_too_long": "신호의 이름이 너무 깁니다.", "no_message_to_remove": "삭제할 신호가 없습니다", "no_use": "사용되지 않음", "no_variable_to_remove": "삭제할 변수가 없습니다.", "no_variable_to_rename": "변경할 변수가 없습니다.", "object_not_found": "블록에서 지정한 오브젝트가 존재하지 않습니다.", "object_not_found_for_paste": "붙여넣기 할 오브젝트가 없습니다.", "people": "일반 사람들", "picture_add": "모양 추가", "plant": "식물", "project": "작품", "project_copied": "의 사본", "PROJECTDEFAULTNAME": ['멋진', '재밌는', '착한', '큰', '대단한', '잘생긴', '행운의'], "remove_object": "오브젝트 삭제", "remove_object_msg": "(이)가 삭제되었습니다.", "removed_msg": "(이)가 성공적으로 삭제 되었습니다.", "rotate_method": "회전방식", "rotation": "방향", "run": "시작하기", "saved": "저장완료", "saved_msg": "(이)가 저장되었습니다.", "save_failed": "저장시 문제가 발생하였습니다. 다시 시도해 주세요.", "select_library": "오브젝트 선택", "select_sprite": "적용할 스프라이트를 하나 이상 선택하세요.", "shape_remove_fail": "모양 삭제 실패", "shape_remove_fail_msg": "적어도 하나 이상의 모양이 존재하여야 합니다.", "shape_remove_ok": "모양이 삭제 되었습니다. ", "shape_remove_ok_msg": "이(가) 삭제 되었습니다.", "sound_add": "소리 추가", "sound_remove_fail": "소리 삭제 실패", "sound_remove_ok": "소리 삭제 완료", "sound_remove_ok_msg": "이(가) 삭제 되었습니다.", "stop": "정지하기", "pause": "일시정지", "restart": "다시시작", "speed": "속도 조절하기", "tab_attribute": "속성", "tab_code": "블록", "tab_picture": "모양", "tab_sound": "소리", "tab_text": "글상자", "textbox": "글상자", "textbox_edit": "글상자 편집", "textbox_input": "글상자의 내용을 입력해주세요.", "things": "물건", "textcoding_tooltip1": "블록코딩과 엔트리파이선을<br/>선택하여 자유롭게<br/>코딩을 해볼 수 있습니다.", "textcoding_tooltip2": "실제 개발 환경과 동일하게<br/>엔트리파이선 모드의 실행 결과를<br/>확인할 수 있습니다.", "textcoding_tooltip3": "엔트리파이선에 대한<br/>기본사항이 안내되어 있습니다.<br/><엔트리파이선 이용안내>를 확인해 주세요!", "upload": "파일 업로드", "upload_addfile": "파일추가", "variable": "변수", "variable_add_calcel": "변수 추가 취소", "variable_add_calcel_msg": "변수 추가를 취소하였습니다.", "variable_add_fail": "변수 추가 실패", "variable_add_fail_msg1": "같은 이름의 변수가 이미 존재합니다.", "variable_add_fail_msg2": "변수의 이름이 적절하지 않습니다.", "variable_add_ok": "변수 추가 완료", "variable_add_ok_msg": "을(를) 추가하였습니다.", "variable_create": "변수 만들기", "variable_add": "변수 추가", "variable_dup": "같은 이름의 변수가 이미 존재합니다.", "variable_newname": "새로운 이름", "variable_remove": "변수 삭제", "variable_remove_canceled": "변수 삭제를 취소하였습니다.", "variable_rename": "변수 이름을 변경합니다. ", "variable_rename_failed": "변수 이름 변경에 실패하였습니다. ", "variable_rename_msg": "'변수의 이름이 성공적으로 변경 되었습니다.'", "variable_rename_ok": "변수의 이름이 성공적으로 변경 되었습니다.", "variable_select": "변수를 선택하세요", "variable_too_long": "변수의 이름이 너무 깁니다.", "vehicle": "탈것", "add_object_alert_msg": "오브젝트를 추가해주세요", "add_object_alert": "경고", "create_variable_block": "변수 만들기", "create_list_block": "리스트 만들기", "Variable_Timer": "초시계", "Variable_placeholder_name": "변수 이름", "Variable_use_all_objects": "모든 오브젝트에서 사용", "Variable_use_this_object": "이 오브젝트에서 사용", "Variable_used_at_all_objects": "모든 오브젝트에서 사용되는 변수", "Variable_create_cloud": "공유 변수로 사용 <br>(서버에 저장됩니다)", "Variable_used_at_special_object": "특정 오브젝트에서만 사용되는 변수 입니다. ", "draw_new": "새로 그리기", "draw_new_ebs": "직접 그리기", "painter_file": "파일 ▼", "painter_file_save": "저장하기", "painter_file_saveas": "새 모양으로 저장", "painter_edit": "편집 ▼", "get_file": "가져오기", "copy_file": "복사하기", "cut_picture": "자르기", "paste_picture": "붙이기", "remove_all": "모두 지우기", "new_picture": "새그림", "picture_size": "크기", "picture_rotation": "회전", "thickness": "굵기", "regular": "보통", "bold": "굵게", "italic": "기울임", "textStyle": "글자", "add_picture": "모양 추가", "select_picture": "모양 선택", "select_sound": "소리 선택", "Size": "크기", "show_variable": "변수 보이기", "default_value": "기본값 ", "slide": "슬라이드", "min_value": "최솟값", "max_value": "최댓값", "number_of_list": "리스트 항목 수", "use_all_objects": "모든 오브젝트에 사용", "list_name": "리스트 이름", "list_used_specific_objects": "특정 오브젝트에서만 사용되는 리스트 입니다. ", "List_used_all_objects": "모든 오브젝트에서 사용되는 리스트", "Scene_delete_error": "장면은 최소 하나 이상 존재해야 합니다.", "Scene_add_error": "장면은 최대 20개까지 추가 가능합니다.", "replica_of_object": "의 복제본", "will_you_delete_scene": "장면은 한번 삭제하면 취소가 불가능 합니다. \n정말 삭제 하시겠습니까?", "will_you_delete_function": "함수는 한번 삭제하면 취소가 불가능 합니다. \n정말 삭제 하시겠습니까?", "duplicate_scene": "복제하기", "block_explain": "블록 설명 ", "block_intro": "블록을 클릭하면 블록에 대한 설명이 나타납니다.", "blocks_reference": "블록 설명", "hardware_guide": "하드웨어 연결 안내", "robot_guide": "로봇 연결 안내", "python_guide": "엔트리파이선 이용 안내", "show_list_workspace": "리스트 보이기", "List_create_cloud": "공유 리스트로 사용 <br>(서버에 저장됩니다)", "confirm_quit": "바꾼 내용을 저장하지 않았습니다.", "confirm_load_temporary": "저장되지 않은 작품이 있습니다. 여시겠습니까?", "login_to_save": "로그인후에 저장 바랍니다.", "cannot_save_in_edit_func": "함수 편집중에는 저장할 수 없습니다.", "new_object": "새 오브젝트", "arduino_connect": "하드웨어 연결", "arduino_connect_success": "하드웨어가 연결되었습니다.", "confirm_load_header": "작품 복구", "uploading_msg": "업로드 중입니다", "upload_fail_msg": "업로드에 실패하였습니다.</br>다시 한번 시도해주세요.", "upload_not_supported_msg": "지원하지 않는 형식입니다.", "upload_not_supported_file_msg": "지원하지 않는 형식의 파일입니다.", "file_converting_msg": "파일 변환 중입니다.", "file_converting_fail_msg": "파일 변환에 실패하였습니다.", "fail_contact_msg": "문제가 계속된다면</br>[email protected] 로 문의해주세요.", "saving_msg": "저장 중입니다", "saving_fail_msg": "저장에 실패하였습니다.</br>다시 한번 시도해주세요.", "loading_msg": "불러오는 중입니다", "loading_fail_msg": "불러오기에 실패하였습니다.</br>다시 한번 시도해주세요.", "restore_project_msg": "정상적으로 저장되지 않은 작품이 있습니다. 해당 작품을 복구하시겠습니까?", "quit_stop_msg": "저장 중에는 종료하실 수 없습니다.", "ent_drag_and_drop": "업로드 하려면 파일을 놓으세요", "not_supported_file_msg": "지원하지 않은 형식의 파일입니다.", "broken_file_msg": "파일이 깨졌거나 잘못된 파일을 불러왔습니다.", "check_audio_msg": "MP3 파일만 업로드가 가능합니다.", "check_entry_file_msg": "ENT 파일만 불러오기가 가능합니다.", "hardware_version_alert_text": "5월 30일 부터 구버전의 연결프로그램의 사용이 중단 됩니다.\n하드웨어 연결 프로그램을 최신 버전으로 업데이트 해주시기 바랍니다.", "variable_name_auto_edited_title": "변수 이름 자동 변경", "variable_name_auto_edited_content": "변수의 이름은 10글자를 넘을 수 없습니다.", "list_name_auto_edited_title": "리스트 이름 자동 변경", "list_name_auto_edited_content": "리스트의 이름은 10글자를 넘을 수 없습니다.", "cloned_scene": "복제본_", "default_mode": "기본형", "practical_course_mode": "교과형", "practical_course": "실과", "select_mode": "모드선택", "select_mode_popup_title": "엔트리 만들기 환경을 선택해 주세요.", "select_mode_popup_lable1": "기본형", "select_mode_popup_lable2": "교과형", "select_mode_popup_desc1": "엔트리의 모든 기능을 이용하여<br/>자유롭게 작품을 만듭니다.", "select_mode_popup_desc2": "실과 교과서에 등장하는 기능만을<br/>이용하여 작품을 만듭니다.", "practical_course_notice": "안내", "practical_course_desc": "<span class='practical_cource_title'>교과용 만들기</span>는<br />실과 교과서로 소프트웨어를 배울 때<br />필요한 기능만을 제공합니다.", "practical_course_desc2": "*기본형 작품 만들기를 이용하면 더 많은 기능을<br />이용해 작품을 만들 수 있습니다.", "practical_course_tooltip": "모든 기능을 이용하기 위해서는<br/>기본형을 선택해 주세요.", "name_already_exists": "이름이 중복 되었습니다.", "enter_the_name": "이름을 입력하여 주세요.", "object_not_exist_error": "오브젝트가 존재하지 않습니다. 오브젝트를 추가한 후 시도해주세요.", "workspace_tutorial_popup_desc": "<span class='practical_cource_title'>작품 만들기</span>는<br />창의적인 작품을 만들 수 있도록<br /> 다양한 블록과 기능을 제공합니다.", "start_guide_tutorial": "만들기 이용 안내" }; Lang.code = "코드보기"; Lang.EntryStatic = { "groupProject": "학급 공유하기", "usage_parallel": "병렬", "usage_hw": "하드웨어", "usage_sequence": "순차", "privateProject": "나만보기", "privateCurriculum": "나만보기", "publicCurriculum": "강의 모음 공유하기", "publicProject": "작품 공유하기", "group": "학급 공유하기", "groupCurriculum": "학급 공유하기", "private": "나만보기", "public": "강의 공유하기", "lecture_is_open_true": "공개", "lecture_is_open_false": "비공개", "category_all": "모든 작품", "category_game": "게임", "category_animation": "애니메이션", "category_media_art": "미디어 아트", "category_physical": "피지컬", "category_etc": "기타", "category_category_game": "게임", "category_category_animation": "애니메이션", "category_category_media_art": "미디어 아트", "category_category_physical": "피지컬", "category_category_etc": "기타", "sort_created": "최신순", "sort_updated": "최신순", "sort_visit": "조회순", "sort_likeCnt": "좋아요순", "sort_comment": "댓글순", "period_all": "전체기간", "period_1": "오늘", "period_7": "최근 1주일", "period_30": "최근 1개월", "period_90": "최근 3개월", "lecture_required_time_1": " ~ 15분", "lecture_required_time_2": "15분 ~ 30분", "lecture_required_time_3": "30분 ~ 45분", "lecture_required_time_4": "45 분 ~ 60분", "lecture_required_time_5": "1시간 이상", "usage_event": "이벤트", "usage_signal": "신호보내기", "usage_scene": "장면", "usage_repeat": "반복", "usage_condition_repeat": "조건반복", "usage_condition": "선택", "usage_clone": "복제본", "usage_rotation": "회전", "usage_coordinate": "좌표이동", "usage_arrow_move": "화살표이동", "usage_shape": "모양", "usage_speak": "말하기", "usage_picture_effect": "그림효과", "usage_textBox": "글상자", "usage_draw": "그리기", "usage_sound": "소리", "usage_confirm": "판단", "usage_comp_operation": "비교연산", "usage_logical_operation": "논리연산", "usage_math_operation": "수리연산", "usage_random": "무작위수", "usage_timer": "초시계", "usage_variable": "변수", "usage_list": "리스트", "usage_ask_answer": "입출력", "usage_function": "함수", "usage_arduino": "아두이노", "concept_resource_analytics": "자료수집/분석/표현", "concept_procedual": "알고리즘과 절차", "concept_abstractive": "추상화", "concept_individual": "문제분해", "concept_automation": "자동화", "concept_simulation": "시뮬레이션", "concept_parallel": "병렬화", "subject_korean": "국어", "subject_english": "영어", "subject_mathmatics": "수학", "subject_social": "사회", "subject_science": "과학", "subject_music": "음악", "subject_paint": "미술", "subject_athletic": "체육", "subject_courtesy": "도덕", "subject_progmatic": "실과", "lecture_grade_1": "초1", "lecture_grade_2": "초2", "lecture_grade_3": "초3", "lecture_grade_4": "초4", "lecture_grade_5": "초5", "lecture_grade_6": "초6", "lecture_grade_7": "중1", "lecture_grade_8": "중2", "lecture_grade_9": "중3", "lecture_grade_10": "일반", "lecture_level_1": "쉬움", "lecture_level_2": "중간", "lecture_level_3": "어려움", "listEnable": "리스트", "functionEnable": "함수", "messageEnable": "신호", "objectEditable": "오브젝트", "pictureeditable": "모양", "sceneEditable": "장면", "soundeditable": "소리", "variableEnable": "변수", "e_1": "초등 1학년", "e_2": "초등 2학년", "e_3": "초등 3학년", "e_4": "초등 4학년", "e_5": "초등 5학년", "e_6": "초등 6학년", "m_1": "중등 1학년", "m_2": "중등 2학년", "m_3": "중등 3학년", "general": "일반", "curriculum_is_open_true": "공개", "curriculum_open_false": "비공개", "notice": "공지사항", "qna": "묻고답하기", "tips": "노하우&팁", "free": "자유 게시판", "report": "제안 및 건의", "art_category_all": "모든 작품", "art_category_game": "게임", "art_category_animation": "애니메이션", "art_category_physical": "피지컬", "art_category_etc": "기타", "art_category_media": "미디어 아트", "art_sort_updated": "최신순", "art_sort_visit": "조회순", "art_sort_likeCnt": "좋아요순", "art_sort_comment": "댓글순", "art_period_all": "전체기간", "art_period_day": "오늘", "art_period_week": "최근 1주일", "art_period_month": "최근 1개월", "art_period_three_month": "최근 3개월", "level_high": "상", "level_mid": "중", "level_row": "하", "discuss_sort_created": "최신순", "discuss_sort_visit": "조회순", "discuss_sort_likesLength": "좋아요순", "discuss_sort_commentsLength": "댓글순", "discuss_period_all": "전체기간", "discuss_period_day": "오늘", "discuss_period_week": "최근 1주일", "discuss_period_month": "최근 1개월", "discuss_period_three_month": "최근 3개월" }; Lang.Helper = { "when_run_button_click": "시작하기 버튼을 클릭하면 아래에 연결된 블록들을 실행합니다.", "when_some_key_pressed": "지정된 키를 누르면 아래에 연결된 블록들을 실행 합니다", "mouse_clicked": "마우스를 클릭 했을 때 아래에 연결된 블록들을 실행 합니다.", "mouse_click_cancled": "마우스 클릭을 해제 했을 때 아래에 연결된 블록들을 실행합니다.", "when_object_click": "해당 오브젝트를 클릭했을 때 아래에 연결된 블록들을 실행합니다.", "when_object_click_canceled": "해당 오브젝트 클릭을 해제 했을때 아래에 연결된 블록들을 실행 합니다.", "when_message_cast": "해당 신호를 받으면 연결된 블록들을 실행합니다.", "message_cast": "목록에 선택된 신호를 보냅니다.", "message_cast_wait": "목록에 선택된 신호를 보내고, 해당 신호를 받는 블록들의 실행이 끝날때 까지 기다립니다.", "when_scene_start": "장면이 시작되면 아래에 연결된 블록들을 실행 합니다. ", "start_scene": "선택한 장면을 시작 합니다.", "start_neighbor_scene": "이전 장면 또는 다음 장면을 시작합니다.", "wait_second": "설정한 시간만큼 기다린 후 다음 블록을 실행 합니다.", "repeat_basic": "설정한 횟수만큼 감싸고 있는 블록들을 반복 실행합니다.", "repeat_inf": "감싸고 있는 블록들을 계속해서 반복 실행합니다.", "repeat_while_true": "판단이 참인 동안 감싸고 있는 블록들을 반복 실행합니다.", "stop_repeat": "이 블록을 감싸는 가장 가까운 반복 블록의 반복을 중단 합니다.", "_if": "만일 판단이 참이면, 감싸고 있는 블록들을 실행합니다.", "if_else": "만일 판단이 참이면, 첫 번째 감싸고 있는 블록들을 실행하고, 거짓이면 두 번째 감싸고 있는 블록들을 실행합니다.", "restart_project": "모든 오브젝트를 처음부터 다시 실행합니다.", "stop_object": "모든 : 모든 오브젝트들이 즉시 실행을 멈춥니다. <br> 자신 : 해당 오브젝트의 모든 블록들을 멈춥니다. <br> 이 코드 : 이 블록이 포함된 코드가 즉시 실행을 멈춥니다. <br> 자신의 다른 코드 : 해당 오브젝트 중 이 블록이 포함된 코드를 제외한 모든 코드가 즉시 실행을 멈춥니다.<br/>다른 오브젝트의 : 다른 오브젝트의 모든 블록들을 멈춥니다.", "wait_until_true": "판단이 참이 될 때까지 실행을 멈추고 기다립니다.", "when_clone_start": "해당 오브젝트의 복제본이 새로 생성되었을 때 아래에 연결된 블록들을 실행합니다.", "create_clone": "선택한 오브젝트의 복제본을 생성합니다.", "delete_clone": "‘복제본이 처음 생성되었을 때’ 블록과 함께 사용하여 생성된 복제본을 삭제합니다.", "remove_all_clones": "해당 오브젝트의 모든 복제본을 삭제합니다.", "move_direction": "설정한 값만큼 오브젝트의 이동방향 화살표가 가리키는 방향으로 움직입니다.", "move_x": "오브젝트의 X좌표를 설정한 값만큼 바꿉니다. ", "move_y": "오브젝트의 Y좌표를 설정한 값만큼 바꿉니다.", "move_xy_time": "오브젝트가 입력한 시간에 걸쳐 x와 y좌표를 설정한 값만큼 바꿉니다", "locate_object_time": "오브젝트가 입력한 시간에 걸쳐 선택한 오브젝트 또는 마우스 포인터의 위치로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_x": "오브젝트가 입력한 x좌표로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_y": "오브젝트가 입력한 y좌표로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_xy": "오브젝트가 입력한 x와 y좌표로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_xy_time": "오브젝트가 입력한 시간에 걸쳐 지정한 x, y좌표로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate": "오브젝트가 선택한 오브젝트 또는 마우스 포인터의 위치로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "rotate_absolute": "해당 오브젝트의 방향을 입력한 각도로 정합니다.", "rotate_by_time": "오브젝트의 방향을 입력한 시간에 걸쳐 입력한 각도만큼 시계방향으로 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "rotate_relative": "오브젝트의 방향을 입력한 각도만큼 시계방향으로 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "direction_absolute": "해당 오브젝트의 이동 방향을 입력한 각도로 정합니다.", "direction_relative": "오브젝트의 이동 방향을 입력한 각도만큼 회전합니다.", "move_to_angle": "설정한 각도 방향으로 입력한 값만큼 움직입니다. (실행화면 위쪽이 0도, 시계방향으로 갈수록 각도 증가)", "see_angle_object": "해당 오브젝트가 다른 오브젝트 또는 마우스 포인터 쪽을 바라봅니다. 오브젝트의 이동방향이 선택된 항목을 향하도록 오브젝트의 방향을 회전해줍니다.", "bounce_wall": "해당 오브젝트가 화면 끝에 닿으면 튕겨져 나옵니다. ", "show": "해당 오브젝트를 화면에 나타냅니다.", "hide": "해당 오브젝트를 화면에서 보이지 않게 합니다.", "dialog_time": "오브젝트가 입력한 내용을 입력한 시간 동안 말풍선으로 말한 후 다음 블록이 실행됩니다.", "dialog": "오브젝트가 입력한 내용을 말풍선으로 말하는 동시에 다음 블록이 실행됩니다.", "remove_dialog": "오브젝트가 말하고 있는 말풍선을 지웁니다.", "change_to_some_shape": "오브젝트를 선택한 모양으로 바꿉니다. (내부 블록을 분리하면 모양의 번호를 사용하여 모양 선택 가능)", "change_to_next_shape": "오브젝트의 모양을 다음 모양으로 바꿉니다.", "set_effect_volume": "해당 오브젝트에 선택한 효과를 입력한 값만큼 줍니다.", "set_effect_amount": "색깔 : 오브젝트에 색깔 효과를 입력한 값만큼 줍니다. (0~100을 주기로 반복됨)<br>밝기 : 오브젝트에 밝기 효과를 입력한 값만큼 줍니다. (-100~100 사이의 범위, -100 이하는 -100으로 100 이상은 100으로 처리 됨) <br> 투명도 : 오브젝트에 투명도 효과를 입력한 값만큼 줍니다. (0~100 사이의 범위, 0이하는 0으로, 100 이상은 100으로 처리됨)", "set_effect": "해당 오브젝트에 선택한 효과를 입력한 값으로 정합니다.", "set_entity_effect": "해당 오브젝트에 선택한 효과를 입력한 값으로 정합니다.", "add_effect_amount": "해당 오브젝트에 선택한 효과를 입력한 값만큼 줍니다.", "change_effect_amount": "색깔 : 오브젝트의 색깔 효과를 입력한 값으로 정합니다. (0~100을 주기로 반복됨) <br> 밝기 : 오브젝트의 밝기 효과를 입력한 값으로 정합니다. (-100~100 사이의 범위, -100 이하는 -100으로 100 이상은 100으로 처리 됨) <br> 투명도 : 오브젝트의 투명도 효과를 입력한 값으로 정합니다. (0~100 사이의 범위, 0이하는 0으로, 100 이상은 100으로 처리됨)", "change_scale_percent": "해당 오브젝트의 크기를 입력한 값만큼 바꿉니다.", "set_scale_percent": "해당 오브젝트의 크기를 입력한 값으로 정합니다.", "change_scale_size": "해당 오브젝트의 크기를 입력한 값만큼 바꿉니다.", "set_scale_size": "해당 오브젝트의 크기를 입력한 값으로 정합니다.", "flip_x": "해당 오브젝트의 상하 모양을 뒤집습니다.", "flip_y": "해당 오브젝트의 좌우 모양을 뒤집습니다.", "change_object_index": "맨 앞으로 : 해당 오브젝트를 화면의 가장 앞쪽으로 가져옵니다. <br> 앞으로 : 해당 오브젝트를 한 층 앞쪽으로 가져옵니다. <br> 뒤로 : 해당 오브젝트를 한 층 뒤쪽으로 보냅니다. <br> 맨 뒤로 : 해당 오브젝트를 화면의 가장 뒤쪽으로 보냅니다.", "set_object_order": "해당 오브젝트가 설정한 순서로 올라옵니다.", "brush_stamp": "오브젝트의 모양을 도장처럼 실행화면 위에 찍습니다.", "start_drawing": "오브젝트가 이동하는 경로를 따라 선이 그려지기 시작합니다. (오브젝트의 중심점이 기준)", "stop_drawing": "오브젝트가 선을 그리는 것을 멈춥니다.", "set_color": "오브젝트가 그리는 선의 색을 선택한 색으로 정합니다.", "set_random_color": "오브젝트가 그리는 선의 색을 무작위로 정합니다. ", "change_thickness": "오브젝트가 그리는 선의 굵기를 입력한 값만큼 바꿉니다. (1~무한의 범위, 1 이하는 1로 처리)", "set_thickness": "오브젝트가 그리는 선의 굵기를 입력한 값으로 정합니다. (1~무한의 범위, 1 이하는 1로 처리)", "change_opacity": "해당 오브젝트가 그리는 붓의 투명도를 입력한 값만큼 바꿉니다.", "change_brush_transparency": "해당 오브젝트가 그리는 붓의 투명도를 입력한 값만큼 바꿉니다. (0~100의 범위, 0이하는 0, 100 이상은 100으로 처리)", "set_opacity": "해당 오브젝트가 그리는 붓의 투명도를 입력한 값으로 정합니다.", "set_brush_tranparency": "해당 오브젝트가 그리는 붓의 투명도를 입력한 값으로 정합니다. (0~100의 범위, 0이하는 0, 100 이상은 100으로 처리)", "brush_erase_all": "해당 오브젝트가 그린 선과 도장을 모두 지웁니다.", "sound_something_with_block": "해당 오브젝트가 선택한 소리를 재생하는 동시에 다음 블록을 실행합니다.", "sound_something_second_with_block": "해당 오브젝트가 선택한 소리를 입력한 시간 만큼만 재생하는 동시에 다음 블록을 실행합니다.", "sound_something_wait_with_block": "해당 오브젝트가 선택한 소리를 재생하고, 소리 재생이 끝나면 다음 블록을 실행합니다.", "sound_something_second_wait_with_block": "해당 오브젝트가 선택한 소리를 입력한 시간 만큼만 재생하고, 소리 재생이 끝나면 다음 블록을 실행합니다.", "sound_volume_change": "작품에서 재생되는 모든 소리의 크기를 입력한 퍼센트만큼 바꿉니다.", "sound_volume_set": "작품에서 재생되는 모든 소리의 크기를 입력한 퍼센트로 정합니다.", "sound_silent_all": "현재 재생중인 모든 소리를 멈춥니다.", "is_clicked": "마우스를 클릭한 경우 ‘참’으로 판단합니다.", "is_press_some_key": "선택한 키가 눌려져 있는 경우 ‘참’으로 판단합니다.", "reach_something": "해당 오브젝트가 선택한 항목과 닿은 경우 ‘참’으로 판단합니다.", "is_included_in_list": "선택한 리스트에 입력한 값을 가진 항목이 포함되어 있는지 확인합니다.", "boolean_basic_operator": "= : 왼쪽에 위치한 값과 오른쪽에 위치한 값이 같으면 '참'으로 판단합니다.<br>> : 왼쪽에 위치한 값이 오른쪽에 위치한 값보다 크면 '참'으로 판단합니다.<br>< : 왼쪽에 위치한 값이 오른쪽에 위치한 값보다 작으면 '참'으로 판단합니다.<br>≥ : 왼쪽에 위치한 값이 오른쪽에 위치한 값보다 크거나 같으면 '참'으로 판단합니다.<br>≤ : 왼쪽에 위치한 값이 오른쪽에 위치한 값보다 작거나 같으면 '참'으로 판단합니다.", "function_create": "자주 쓰는 코드를 이 블록 아래에 조립하여 함수로 만듭니다. [함수 정의하기]의 오른쪽 빈칸에 [이름]을 조립하여 함수의 이름을 정할 수 있습니다. 함수를 실행하는 데 입력값이 필요한 경우 빈칸에 [문자/숫자값], [판단값]을 조립하여 매개변수로 사용합니다.", "function_field_label": "'함수 정의하기'의 빈칸 안에 조립하고, 이름을 입력하여 함수의 이름을 정해줍니다. ", "function_field_string": "해당 함수를 실행하는데 문자/숫자 값이 필요한 경우 빈칸 안에 조립하여 매개변수로 사용합니다. 이 블록 내부의[문자/숫자값]을 분리하여 함수의 코드 중 필요한 부분에 넣어 사용합니다.", "function_field_boolean": "해당 함수를 실행하는 데 참 또는 거짓의 판단이 필요한 경우 빈칸 안에 조립하여 매개변수로 사용합니다. 이 블록 내부의 [판단값]을 분리하여 함수의 코드 중 필요한 부분에 넣어 사용합니다.", "function_general": "현재 만들고 있는 함수 블록 또는 지금까지 만들어 둔 함수 블록입니다.", "boolean_and": "두 판단이 모두 참인 경우 ‘참’으로 판단합니다.", "boolean_or": "두 판단 중 하나라도 참이 있는 경우 ‘참’으로 판단합니다.", "boolean_not": "해당 판단이 참이면 거짓, 거짓이면 참으로 만듭니다.", "calc_basic": "+ : 입력한 두 수를 더한 값입니다.<br>- : 입력한 두 수를 뺀 값입니다.<br>X : 입력한 두 수를 곱한 값입니다.<br>/ : 입력한 두 수를 나눈 값입니다.", "calc_rand": "입력한 두 수 사이에서 선택된 무작위 수의 값입니다. (두 수 모두 정수를 입력한 경우 정수로, 두 수 중 하나라도 소수를 입력한 경우 소수로 무작위 수가 선택됩니다.)", "get_x_coordinate": "해당 오브젝트의 x 좌푯값을 의미합니다.", "get_y_coordinate": "해당 오브젝트의 y 좌푯값을 의미합니다.", "coordinate_mouse": "마우스 포인터의 x 또는 y의 좌표 값을 의미합니다.", "coordinate_object": "선택한 오브젝트 또는 자신의 각종 정보값(x좌표, y좌표, 방향, 이동방향, 크기, 모양번호, 모양이름)입니다.", "quotient_and_mod": "몫 : 앞의 수에서 뒤의 수를 나누어 생긴 몫의 값입니다. <br> 나머지 : 앞의 수에서 뒤의 수를 나누어 생긴 나머지 값입니다.", "get_rotation_direction": "해당 오브젝트의 방향값, 이동 방향값을 의미합니다.", "calc_share": "앞 수에서 뒤 수를 나누어 생긴 몫을 의미합니다.", "calc_mod": "앞 수에서 뒤 수를 나누어 생긴 나머지를 의미합니다.", "calc_operation": "입력한 수에 대한 다양한 수학식의 계산값입니다.", "get_date": "현재 연도, 월, 일, 시각과 같이 시간에 대한 값입니다.", "distance_something": "자신과 선택한 오브젝트 또는 마우스 포인터 간의 거리 값입니다.", "get_sound_duration": "선택한 소리의 길이(초) 값입니다.", "get_project_timer_value": "이 블록이 실행되는 순간 초시계에 저장된 값입니다.", "choose_project_timer_action": "시작하기: 초시계를 시작합니다. <br> 정지하기: 초시계를 정지합니다. <br> 초기화하기: 초시계의 값을 0으로 초기화합니다. <br> (이 블록을 블록조립소로 가져오면 실행화면에 ‘초시계 창’이 생성됩니다.)", "reset_project_timer": "실행되고 있던 타이머를 0으로 초기화합니다.", "set_visible_project_timer": "초시계 창을 화면에서 숨기거나 보이게 합니다.", "ask_and_wait": "해당 오브젝트가 입력한 문자를 말풍선으로 묻고, 대답을 입력받습니다. (이 블록을 블록조립소로 가져오면 실행화면에 ‘대답 창’이 생성됩니다.)", "get_canvas_input_value": "묻고 기다리기에 의해 입력된 값입니다.", "set_visible_answer": "실행화면에 있는 ‘대답 창’을 보이게 하거나 숨길 수 있습니다.", "combine_something": "입력한 두 자료를 결합한 값입니다.", "get_variable": "선택된 변수에 저장된 값입니다.", "change_variable": "선택한 변수에 입력한 값을 더합니다.", "set_variable": "선택한 변수의 값을 입력한 값으로 정합니다.", "robotis_carCont_sensor_value": "왼쪽 접속 센서 : 접촉(1), 비접촉(0) 값 입니다.<br/>오른쪽 접촉 센서 : 접촉(1), 비접촉(0) 값 입니다.<br/>선택 버튼 상태 : 접촉(1), 비접촉(0) 값 입니다.<br/>최종 소리 감지 횟수 : 마지막 실시간 소리 감지 횟수 값 입니다.<br/>실시간 소리 감지 횟수 : 약 1초 안에 다음 소리가 감지되면 1씩 증가합니다.<br/>왼쪽 적외선 센서 : 물체와 가까울 수록 큰 값 입니다.<br/>오른쪽 적외선 센서 : 물체와 가까울 수록 큰 값 값 입니다.<br/>왼쪽 적외선 센서 캘리브레이션 값 : 적외선 센서의 캘리브레이션 값 입니다.<br/>오른쪽 적외선 센서 캘리브레이션 값 : 적외선 센서의 캘리브레이션 값 입니다.<br/>(*캘리브레이션 값 - 적외선센서 조정 값)", "robotis_carCont_cm_led": "4개의 LED 중 1번 또는 4번 LED 를 켜거나 끕니다.<br/>LED 2번과 3번은 동작 지원하지 않습니다.", "robotis_carCont_cm_sound_detected_clear": "최종 소리 감지횟 수를 0 으로 초기화 합니다.", "robotis_carCont_aux_motor_speed": "감속모터 속도를 0 ~ 1023 의 값(으)로 정합니다.", "robotis_carCont_cm_calibration": "적외선센서 조정 값(http://support.robotis.com/ko/: 자동차로봇> 2. B. 적외선 값 조정)을 직접 정합니다.", "robotis_openCM70_sensor_value": "최종 소리 감지 횟수 : 마지막 실시간 소리 감지 횟수 값 입니다.<br/>실시간 소리 감지 횟수 : 약 1초 안에 다음 소리가 감지되면 1씩 증가합니다.<br/>사용자 버튼 상태 : 접촉(1), 비접촉(0) 값 입니다.최종 소리 감지 횟수 : 마지막 실시간 소리 감지 횟수 값 입니다.<br/>실시간 소리 감지 횟수 : 약 1초 안에 다음 소리가 감지되면 1씩 증가합니다.<br/>사용자 버튼 상태 : 접촉(1), 비접촉(0) 값 입니다.", "robotis_openCM70_aux_sensor_value": "서보모터 위치 : 0 ~ 1023, 중간 위치의 값은 512 입니다.<br/>적외선센서 : 물체와 가까울 수록 큰 값 입니다.<br/>접촉센서 : 접촉(1), 비접촉(0) 값 입니다.<br/>조도센서(CDS) : 0 ~ 1023, 밝을 수록 큰 값 입니다.<br/>온습도센서(습도) : 0 ~ 100, 습할 수록 큰 값 입니다.<br/>온습도센서(온도) : -20 ~ 100, 온도가 높을 수록 큰 값 입니다.<br/>온도센서 : -20 ~ 100, 온도가 높을 수록 큰 값 입니다.<br/>초음파센서 : -<br/>자석센서 : 접촉(1), 비접촉(0) 값 입니다.<br/>동작감지센서 : 동작 감지(1), 동작 미감지(0) 값 입니다.<br/>컬러센서 : 알수없음(0), 흰색(1), 검은색(2), 빨간색(3), 녹색(4), 파란색(5), 노란색(6) 값 입니다.<br/>사용자 장치 : 사용자 센서 제작에 대한 설명은 ROBOTIS e-매뉴얼(http://support.robotis.com/ko/)을 참고하세요.", "robotis_openCM70_cm_buzzer_index": "음계를 0.1 ~ 5 초 동안 연주 합니다.", "robotis_openCM70_cm_buzzer_melody": "멜로디를 연주 합니다.<br/>멜로디를 연속으로 재생하는 경우, 다음 소리가 재생되지 않으면 '흐름 > X 초 기다리기' 블록을 사용하여 기다린 후 실행합니다.", "robotis_openCM70_cm_sound_detected_clear": "최종 소리 감지횟 수를 0 으로 초기화 합니다.", "robotis_openCM70_cm_led": "제어기의 빨간색, 녹색, 파란색 LED 를 켜거나 끕니다.", "robotis_openCM70_cm_motion": "제어기에 다운로드 되어있는 모션을 실행합니다.", "robotis_openCM70_aux_motor_speed": "감속모터 속도를 0 ~ 1023 의 값(으)로 정합니다.", "robotis_openCM70_aux_servo_mode": "서보모터를 회전모드 또는 관절모드로 정합니다.<br/>한번 설정된 모드는 계속 적용됩니다.<br/>회전모드는 서보모터 속도를 지정하여 서보모터를 회전 시킵니다.<br/>관절모드는 지정한 서보모터 속도로 서보모터 위치를 이동 시킵니다.", "robotis_openCM70_aux_servo_speed": "서보모터 속도를 0 ~ 1023 의 값(으)로 정합니다.", "robotis_openCM70_aux_servo_position": "서보모터 위치를 0 ~ 1023 의 값(으)로 정합니다.<br/>서보모터 속도와 같이 사용해야 합니다.", "robotis_openCM70_aux_led_module": "LED 모듈의 LED 를 켜거나 끕니다.", "robotis_openCM70_aux_custom": "사용자 센서 제작에 대한 설명은 ROBOTIS e-매뉴얼(http://support.robotis.com/ko/)을 참고하세요.", "robotis_openCM70_cm_custom_value": "컨트롤 테이블 주소를 직접 입력하여 값을 확인 합니다.<br/>컨트롤 테이블 대한 설명은 ROBOTIS e-매뉴얼(http://support.robotis.com/ko/)을 참고하세요.", "robotis_openCM70_cm_custom": "컨트롤 테이블 주소를 직접 입력하여 값을 정합니다.<br/>컨트롤 테이블 대한 설명은 ROBOTIS e-매뉴얼(http://support.robotis.com/ko/)을 참고하세요.", "show_variable": "선택한 변수 창을 실행화면에 보이게 합니다.", "hide_variable": "선택한 변수 창을 실행화면에서 숨깁니다.", "value_of_index_from_list": "선택한 리스트에서 선택한 값의 순서에 있는 항목 값을 의미합니다. (내부 블록을 분리하면 순서를 숫자로 입력 가능)", "add_value_to_list": "입력한 값이 선택한 리스트의 마지막 항목으로 추가됩니다.", "remove_value_from_list": "선택한 리스트의 입력한 순서에 있는 항목을 삭제합니다.", "insert_value_to_list": "선택한 리스트의 입력한 순서의 위치에 입력한 항목을 넣습니다. (입력한 항목의 뒤에 있는 항목들은 순서가 하나씩 밀려납니다.)", "change_value_list_index": "선택한 리스트에서 입력한 순서에 있는 항목의 값을 입력한 값으로 바꿉니다.", "length_of_list": "선택한 리스트가 보유한 항목 개수 값입니다.", "show_list": "선택한 리스트를 실행화면에 보이게 합니다.", "hide_list": "선택한 리스트를 실행화면에서 숨깁니다.", "text": "해당 글상자가 표시하고 있는 문자값을 의미합니다.", "text_write": "글상자의 내용을 입력한 값으로 고쳐씁니다.", "text_append": "글상자의 내용 뒤에 입력한 값을 추가합니다.", "text_prepend": "글상자의 내용 앞에 입력한 값을 추가합니다.", "text_flush": "글상자에 저장된 값을 모두 지웁니다.", "erase_all_effects": "해당 오브젝트에 적용된 효과를 모두 지웁니다.", "char_at": "입력한 문자/숫자값 중 입력한 숫자 번째의 글자 값입니다.", "length_of_string": "입력한 문자값의 공백을 포함한 글자 수입니다.", "substring": "입력한 문자/숫자 값에서 입력한 범위 내의 문자/숫자 값입니다.", "replace_string": "입력한 문자/숫자 값에서 지정한 문자/숫자 값을 찾아 추가로 입력한 문자/숫자값으로 모두 바꾼 값입니다. (영문 입력시 대소문자를 구분합니다.)", "index_of_string": "입력한 문자/숫자 값에서 지정한 문자/숫자 값이 처음으로 등장하는 위치의 값입니다. (안녕, 엔트리!에서 엔트리의 시작 위치는 5)", "change_string_case": "입력한 영문의 모든 알파벳을 대문자 또는 소문자로 바꾼 문자값을 의미합니다.", "direction_relative_duration": "해당 오브젝트의 이동방향을 입력한 시간에 걸쳐 입력한 각도만큼 시계방향으로 회전합니다. ", "get_sound_volume": "현재 작품에 설정된 소리의 크기값을 의미합니다.", "sound_from_to": "해당 오브젝트가 선택한 소리를 입력한 시간 부분만을 재생하는 동시에 다음 블록을 실행합니다.", "sound_from_to_and_wait": "해당 오브젝트가 선택한 소리를 입력한 시간 부분만을 재생하고, 소리 재생이 끝나면 다음 블록을 실행합니다.", "Block_info": "블록 설명", "Block_click_msg": "블록을 클릭하면 블록에 대한 설명이 나타납니다.", "hamster_beep": "버저 소리를 짧게 냅니다.", "hamster_change_both_wheels_by": "왼쪽과 오른쪽 바퀴의 현재 속도 값(%)에 입력한 값을 각각 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "hamster_change_buzzer_by": "버저 소리의 현재 음 높이(Hz)에 입력한 값을 더합니다. 소수점 둘째 자리까지 입력할 수 있습니다.", "hamster_change_output_by": "선택한 외부 확장 포트의 현재 출력 값에 입력한 값을 더합니다. 더한 결과는 외부 확장 포트의 모드에 따라 다음의 범위를 가집니다.<br/>서보 출력: 유효한 값의 범위는 1 ~ 180도, 0이면 PWM 펄스 없이 항상 0을 출력<br/>PWM 출력: 0 ~ 100%, PWM 파형에서 ON 상태의 듀티비(%)<br/>디지털 출력: 0이면 LOW, 0이 아니면 HIGH", "hamster_change_tempo_by": "연주하거나 쉬는 속도의 현재 BPM(분당 박자 수)에 입력한 값을 더합니다.", "hamster_change_wheel_by": "왼쪽/오른쪽/양쪽 바퀴의 현재 속도 값(%)에 입력한 값을 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "hamster_clear_buzzer": "버저 소리를 끕니다.", "hamster_clear_led": "왼쪽/오른쪽/양쪽 LED를 끕니다.", "hamster_follow_line_until": "왼쪽/오른쪽/앞쪽/뒤쪽의 검은색/하얀색 선을 따라 이동하다가 교차로를 만나면 정지합니다.", "hamster_follow_line_using": "왼쪽/오른쪽/양쪽 바닥 센서를 사용하여 검은색/하얀색 선을 따라 이동합니다.", "hamster_hand_found": "근접 센서 앞에 손 또는 물체가 있으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "hamster_move_backward_for_secs": "입력한 시간(초) 동안 뒤로 이동합니다.", "hamster_move_forward_for_secs": "입력한 시간(초) 동안 앞으로 이동합니다.", "hamster_move_forward_once": "말판 위에서 한 칸 앞으로 이동합니다.", "hamster_play_note_for": "선택한 계이름과 옥타브의 음을 입력한 박자만큼 소리 냅니다.", "hamster_rest_for": "입력한 박자만큼 쉽니다.", "hamster_set_both_wheels_to": "왼쪽과 오른쪽 바퀴의 속도를 입력한 값(-100 ~ 100%)으로 각각 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "hamster_set_buzzer_to": "버저 소리의 음 높이를 입력한 값(Hz)으로 설정합니다. 소수점 둘째 자리까지 입력할 수 있습니다. 숫자 0을 입력하면 버저 소리를 끕니다.", "hamster_set_following_speed_to": "선을 따라 이동하는 속도(1 ~ 8)를 설정합니다. 숫자가 클수록 이동하는 속도가 빠릅니다.", "hamster_set_led_to": "왼쪽/오른쪽/양쪽 LED를 선택한 색깔로 켭니다.", "hamster_set_output_to": "선택한 외부 확장 포트의 출력 값을 입력한 값으로 설정합니다. 입력하는 값은 외부 확장 포트의 모드에 따라 다음의 범위를 가집니다.<br/>서보 출력: 유효한 값의 범위는 1 ~ 180도, 0이면 PWM 펄스 없이 항상 0을 출력<br/>PWM 출력: 0 ~ 100%, PWM 파형에서 ON 상태의 듀티비(%)<br/>디지털 출력: 0이면 LOW, 0이 아니면 HIGH", "hamster_set_port_to": "선택한 외부 확장 포트의 입출력 모드를 선택한 모드로 설정합니다.", "hamster_set_tempo_to": "연주하거나 쉬는 속도를 입력한 BPM(분당 박자 수)으로 설정합니다.", "hamster_set_wheel_to": "왼쪽/오른쪽/양쪽 바퀴의 속도를 입력한 값(-100 ~ 100%)으로 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "hamster_stop": "양쪽 바퀴를 정지합니다.", "hamster_turn_for_secs": "입력한 시간(초) 동안 왼쪽/오른쪽 방향으로 제자리에서 회전합니다.", "hamster_turn_once": "말판 위에서 왼쪽/오른쪽 방향으로 제자리에서 90도 회전합니다.", "hamster_value": "왼쪽 근접 센서: 왼쪽 근접 센서의 값 (값의 범위: 0 ~ 255, 초기값: 0)<br/>오른쪽 근접 센서: 오른쪽 근접 센서의 값 (값의 범위: 0 ~ 255, 초기값: 0)<br/>왼쪽 바닥 센서: 왼쪽 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>오른쪽 바닥 센서: 오른쪽 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>x축 가속도: 가속도 센서의 X축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇이 전진하는 방향이 X축의 양수 방향입니다.<br/>y축 가속도: 가속도 센서의 Y축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 왼쪽 방향이 Y축의 양수 방향입니다.<br/>z축 가속도: 가속도 센서의 Z축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 위쪽 방향이 Z축의 양수 방향입니다.<br/>밝기: 밝기 센서의 값 (값의 범위: 0 ~ 65535, 초기값: 0) 밝을 수록 값이 커집니다.<br/>온도: 로봇 내부의 온도 값 (값의 범위: 섭씨 -40 ~ 88도, 초기값: 0)<br/>신호 세기: 블루투스 무선 통신의 신호 세기 (값의 범위: -128 ~ 0 dBm, 초기값: 0) 신호의 세기가 셀수록 값이 커집니다.<br/>입력 A: 외부 확장 포트 A로 입력되는 신호의 값 (값의 범위: 아날로그 입력 0 ~ 255, 디지털 입력 0 또는 1, 초기값: 0)<br/>입력 B: 외부 확장 포트 B로 입력되는 신호의 값 (값의 범위: 아날로그 입력 0 ~ 255, 디지털 입력 0 또는 1, 초기값: 0)", "roboid_hamster_beep": "버저 소리를 짧게 냅니다.", "roboid_hamster_change_both_wheels_by": "왼쪽과 오른쪽 바퀴의 현재 속도 값(%)에 입력한 값을 각각 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "roboid_hamster_change_buzzer_by": "버저 소리의 현재 음 높이(Hz)에 입력한 값을 더합니다. 소수점 둘째 자리까지 입력할 수 있습니다.", "roboid_hamster_change_output_by": "선택한 외부 확장 포트의 현재 출력 값에 입력한 값을 더합니다. 더한 결과는 외부 확장 포트의 모드에 따라 다음의 범위를 가집니다.<br/>서보 출력: 유효한 값의 범위는 1 ~ 180도, 0이면 PWM 펄스 없이 항상 0을 출력<br/>PWM 출력: 0 ~ 100%, PWM 파형에서 ON 상태의 듀티비(%)<br/>디지털 출력: 0이면 LOW, 0이 아니면 HIGH", "roboid_hamster_change_tempo_by": "연주하거나 쉬는 속도의 현재 BPM(분당 박자 수)에 입력한 값을 더합니다.", "roboid_hamster_change_wheel_by": "왼쪽/오른쪽/양쪽 바퀴의 현재 속도 값(%)에 입력한 값을 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "roboid_hamster_clear_buzzer": "버저 소리를 끕니다.", "roboid_hamster_clear_led": "왼쪽/오른쪽/양쪽 LED를 끕니다.", "roboid_hamster_follow_line_until": "왼쪽/오른쪽/앞쪽/뒤쪽의 검은색/하얀색 선을 따라 이동하다가 교차로를 만나면 정지합니다.", "roboid_hamster_follow_line_using": "왼쪽/오른쪽/양쪽 바닥 센서를 사용하여 검은색/하얀색 선을 따라 이동합니다.", "roboid_hamster_hand_found": "근접 센서 앞에 손 또는 물체가 있으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "roboid_hamster_move_backward_for_secs": "입력한 시간(초) 동안 뒤로 이동합니다.", "roboid_hamster_move_forward_for_secs": "입력한 시간(초) 동안 앞으로 이동합니다.", "roboid_hamster_move_forward_once": "말판 위에서 한 칸 앞으로 이동합니다.", "roboid_hamster_play_note_for": "선택한 계이름과 옥타브의 음을 입력한 박자만큼 소리 냅니다.", "roboid_hamster_rest_for": "입력한 박자만큼 쉽니다.", "roboid_hamster_set_both_wheels_to": "왼쪽과 오른쪽 바퀴의 속도를 입력한 값(-100 ~ 100%)으로 각각 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "roboid_hamster_set_buzzer_to": "버저 소리의 음 높이를 입력한 값(Hz)으로 설정합니다. 소수점 둘째 자리까지 입력할 수 있습니다. 숫자 0을 입력하면 버저 소리를 끕니다.", "roboid_hamster_set_following_speed_to": "선을 따라 이동하는 속도(1 ~ 8)를 설정합니다. 숫자가 클수록 이동하는 속도가 빠릅니다.", "roboid_hamster_set_led_to": "왼쪽/오른쪽/양쪽 LED를 선택한 색깔로 켭니다.", "roboid_hamster_set_output_to": "선택한 외부 확장 포트의 출력 값을 입력한 값으로 설정합니다. 입력하는 값은 외부 확장 포트의 모드에 따라 다음의 범위를 가집니다.<br/>서보 출력: 유효한 값의 범위는 1 ~ 180도, 0이면 PWM 펄스 없이 항상 0을 출력<br/>PWM 출력: 0 ~ 100%, PWM 파형에서 ON 상태의 듀티비(%)<br/>디지털 출력: 0이면 LOW, 0이 아니면 HIGH", "roboid_hamster_set_port_to": "선택한 외부 확장 포트의 입출력 모드를 선택한 모드로 설정합니다.", "roboid_hamster_set_tempo_to": "연주하거나 쉬는 속도를 입력한 BPM(분당 박자 수)으로 설정합니다.", "roboid_hamster_set_wheel_to": "왼쪽/오른쪽/양쪽 바퀴의 속도를 입력한 값(-100 ~ 100%)으로 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "roboid_hamster_stop": "양쪽 바퀴를 정지합니다.", "roboid_hamster_turn_for_secs": "입력한 시간(초) 동안 왼쪽/오른쪽 방향으로 제자리에서 회전합니다.", "roboid_hamster_turn_once": "말판 위에서 왼쪽/오른쪽 방향으로 제자리에서 90도 회전합니다.", "roboid_hamster_value": "왼쪽 근접 센서: 왼쪽 근접 센서의 값 (값의 범위: 0 ~ 255, 초기값: 0)<br/>오른쪽 근접 센서: 오른쪽 근접 센서의 값 (값의 범위: 0 ~ 255, 초기값: 0)<br/>왼쪽 바닥 센서: 왼쪽 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>오른쪽 바닥 센서: 오른쪽 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>x축 가속도: 가속도 센서의 X축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇이 전진하는 방향이 X축의 양수 방향입니다.<br/>y축 가속도: 가속도 센서의 Y축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 왼쪽 방향이 Y축의 양수 방향입니다.<br/>z축 가속도: 가속도 센서의 Z축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 위쪽 방향이 Z축의 양수 방향입니다.<br/>밝기: 밝기 센서의 값 (값의 범위: 0 ~ 65535, 초기값: 0) 밝을 수록 값이 커집니다.<br/>온도: 로봇 내부의 온도 값 (값의 범위: 섭씨 -40 ~ 88도, 초기값: 0)<br/>신호 세기: 블루투스 무선 통신의 신호 세기 (값의 범위: -128 ~ 0 dBm, 초기값: 0) 신호의 세기가 셀수록 값이 커집니다.<br/>입력 A: 외부 확장 포트 A로 입력되는 신호의 값 (값의 범위: 아날로그 입력 0 ~ 255, 디지털 입력 0 또는 1, 초기값: 0)<br/>입력 B: 외부 확장 포트 B로 입력되는 신호의 값 (값의 범위: 아날로그 입력 0 ~ 255, 디지털 입력 0 또는 1, 초기값: 0)", "roboid_turtle_button_state": "등 버튼을 클릭했으면/더블클릭했으면/길게 눌렀으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "roboid_turtle_change_buzzer_by": "버저 소리의 현재 음 높이(Hz)에 입력한 값을 더합니다. 소수점 둘째 자리까지 입력할 수 있습니다.", "roboid_turtle_change_head_led_by_rgb": "머리 LED의 현재 R, G, B 값에 입력한 값을 각각 더합니다.", "roboid_turtle_change_tempo_by": "연주하거나 쉬는 속도의 현재 BPM(분당 박자 수)에 입력한 값을 더합니다.", "roboid_turtle_change_wheel_by": "왼쪽/오른쪽/양쪽 바퀴의 현재 속도 값(%)에 입력한 값을 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "roboid_turtle_change_wheels_by_left_right": "왼쪽과 오른쪽 바퀴의 현재 속도 값(%)에 입력한 값을 각각 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "roboid_turtle_clear_head_led": "머리 LED를 끕니다.", "roboid_turtle_clear_sound": "소리를 끕니다.", "roboid_turtle_cross_intersection": "검은색 교차로에서 잠시 앞으로 이동한 후 검은색 선을 찾아 다시 이동합니다.", "roboid_turtle_follow_line": "하얀색 바탕 위에서 선택한 색깔의 선을 따라 이동합니다.", "roboid_turtle_follow_line_until": "하얀색 바탕 위에서 검은색 선을 따라 이동하다가 선택한 색깔을 컬러 센서가 감지하면 정지합니다.", "roboid_turtle_follow_line_until_black": "하얀색 바탕 위에서 선택한 색깔의 선을 따라 이동하다가 컬러 센서가 검은색을 감지하면 정지합니다.", "roboid_turtle_is_color_pattern": "선택한 색깔 패턴을 컬러 센서가 감지하였으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "roboid_turtle_move_backward_unit": "입력한 거리(cm)/시간(초)/펄스만큼 뒤로 이동합니다.", "roboid_turtle_move_forward_unit": "입력한 거리(cm)/시간(초)/펄스만큼 앞으로 이동합니다.", "roboid_turtle_pivot_around_wheel_unit_in_direction": "왼쪽/오른쪽 바퀴 중심으로 입력한 각도(도)/시간(초)/펄스만큼 머리/꼬리 방향으로 회전합니다.", "roboid_turtle_play_note": "선택한 계이름과 옥타브의 음을 계속 소리 냅니다.", "roboid_turtle_play_note_for_beats": "선택한 계이름과 옥타브의 음을 입력한 박자만큼 소리 냅니다.", "roboid_turtle_play_sound_times": "선택한 소리를 입력한 횟수만큼 재생합니다.", "roboid_turtle_play_sound_times_until_done": "선택한 소리를 입력한 횟수만큼 재생하고, 재생이 완료될 때까지 기다립니다.", "roboid_turtle_rest_for_beats": "입력한 박자만큼 쉽니다.", "roboid_turtle_set_buzzer_to": "버저 소리의 음 높이를 입력한 값(Hz)으로 설정합니다. 소수점 둘째 자리까지 입력할 수 있습니다. 숫자 0을 입력하면 소리를 끕니다.", "roboid_turtle_set_following_speed_to": "선을 따라 이동하는 속도(1 ~ 8)를 설정합니다. 숫자가 클수록 이동하는 속도가 빠릅니다.", "roboid_turtle_set_head_led_to": "머리 LED를 선택한 색깔로 켭니다.", "roboid_turtle_set_head_led_to_rgb": "머리 LED의 R, G, B 값을 입력한 값으로 각각 설정합니다.", "roboid_turtle_set_tempo_to": "연주하거나 쉬는 속도를 입력한 BPM(분당 박자 수)으로 설정합니다.", "roboid_turtle_set_wheel_to": "왼쪽/오른쪽/양쪽 바퀴의 속도를 입력한 값(-400 ~ 400%)으로 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "roboid_turtle_set_wheels_to_left_right": "왼쪽과 오른쪽 바퀴의 속도를 입력한 값(-400 ~ 400%)으로 각각 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "roboid_turtle_stop": "양쪽 바퀴를 정지합니다.", "roboid_turtle_touching_color": "선택한 색깔을 컬러 센서가 감지하였으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "roboid_turtle_turn_at_intersection": "검은색 교차로에서 잠시 앞으로 이동한 후 제자리에서 왼쪽/오른쪽/뒤쪽으로 회전하고 검은색 선을 찾아 다시 이동합니다.", "roboid_turtle_turn_unit_in_place": "입력한 각도(도)/시간(초)/펄스만큼 왼쪽/오른쪽 방향으로 제자리에서 회전합니다.", "roboid_turtle_turn_unit_with_radius_in_direction": "입력한 반지름의 원을 그리면서 입력한 각도(도)/시간(초)/펄스만큼 왼쪽/오른쪽, 머리/꼬리 방향으로 회전합니다.", "roboid_turtle_value": "색깔 번호: 컬러 센서가 감지한 색깔의 번호 (값의 범위: -1 ~ 8, 초기값: -1)<br/>색깔 패턴: 컬러 센서가 감지한 색깔 패턴의 값 (값의 범위: -1 ~ 88, 초기값: -1)<br/>바닥 센서: 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>버튼: 거북이 등 버튼의 상태 값 (누르면 1, 아니면 0, 초기값: 0)<br/>x축 가속도: 가속도 센서의 X축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇이 전진하는 방향이 X축의 양수 방향입니다.<br/>y축 가속도: 가속도 센서의 Y축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 왼쪽 방향이 Y축의 양수 방향입니다.<br/>z축 가속도: 가속도 센서의 Z축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 위쪽 방향이 Z축의 양수 방향입니다.", "turtle_button_state": "등 버튼을 클릭했으면/더블클릭했으면/길게 눌렀으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "turtle_change_buzzer_by": "버저 소리의 현재 음 높이(Hz)에 입력한 값을 더합니다. 소수점 둘째 자리까지 입력할 수 있습니다.", "turtle_change_head_led_by_rgb": "머리 LED의 현재 R, G, B 값에 입력한 값을 각각 더합니다.", "turtle_change_tempo_by": "연주하거나 쉬는 속도의 현재 BPM(분당 박자 수)에 입력한 값을 더합니다.", "turtle_change_wheel_by": "왼쪽/오른쪽/양쪽 바퀴의 현재 속도 값(%)에 입력한 값을 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "turtle_change_wheels_by_left_right": "왼쪽과 오른쪽 바퀴의 현재 속도 값(%)에 입력한 값을 각각 더합니다. 더한 결과가 양수 값이면 바퀴가 앞으로 회전하고, 음수 값이면 뒤로 회전합니다.", "turtle_clear_head_led": "머리 LED를 끕니다.", "turtle_clear_sound": "소리를 끕니다.", "turtle_cross_intersection": "검은색 교차로에서 잠시 앞으로 이동한 후 검은색 선을 찾아 다시 이동합니다.", "turtle_follow_line": "하얀색 바탕 위에서 선택한 색깔의 선을 따라 이동합니다.", "turtle_follow_line_until": "하얀색 바탕 위에서 검은색 선을 따라 이동하다가 선택한 색깔을 컬러 센서가 감지하면 정지합니다.", "turtle_follow_line_until_black": "하얀색 바탕 위에서 선택한 색깔의 선을 따라 이동하다가 컬러 센서가 검은색을 감지하면 정지합니다.", "turtle_is_color_pattern": "선택한 색깔 패턴을 컬러 센서가 감지하였으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "turtle_move_backward_unit": "입력한 거리(cm)/시간(초)/펄스만큼 뒤로 이동합니다.", "turtle_move_forward_unit": "입력한 거리(cm)/시간(초)/펄스만큼 앞으로 이동합니다.", "turtle_pivot_around_wheel_unit_in_direction": "왼쪽/오른쪽 바퀴 중심으로 입력한 각도(도)/시간(초)/펄스만큼 머리/꼬리 방향으로 회전합니다.", "turtle_play_note": "선택한 계이름과 옥타브의 음을 계속 소리 냅니다.", "turtle_play_note_for_beats": "선택한 계이름과 옥타브의 음을 입력한 박자만큼 소리 냅니다.", "turtle_play_sound_times": "선택한 소리를 입력한 횟수만큼 재생합니다.", "turtle_play_sound_times_until_done": "선택한 소리를 입력한 횟수만큼 재생하고, 재생이 완료될 때까지 기다립니다.", "turtle_rest_for_beats": "입력한 박자만큼 쉽니다.", "turtle_set_buzzer_to": "버저 소리의 음 높이를 입력한 값(Hz)으로 설정합니다. 소수점 둘째 자리까지 입력할 수 있습니다. 숫자 0을 입력하면 소리를 끕니다.", "turtle_set_following_speed_to": "선을 따라 이동하는 속도(1 ~ 8)를 설정합니다. 숫자가 클수록 이동하는 속도가 빠릅니다.", "turtle_set_head_led_to": "머리 LED를 선택한 색깔로 켭니다.", "turtle_set_head_led_to_rgb": "머리 LED의 R, G, B 값을 입력한 값으로 각각 설정합니다.", "turtle_set_tempo_to": "연주하거나 쉬는 속도를 입력한 BPM(분당 박자 수)으로 설정합니다.", "turtle_set_wheel_to": "왼쪽/오른쪽/양쪽 바퀴의 속도를 입력한 값(-400 ~ 400%)으로 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "turtle_set_wheels_to_left_right": "왼쪽과 오른쪽 바퀴의 속도를 입력한 값(-400 ~ 400%)으로 각각 설정합니다. 양수 값을 입력하면 바퀴가 앞으로 회전하고, 음수 값을 입력하면 뒤로 회전합니다. 숫자 0을 입력하면 정지합니다.", "turtle_stop": "양쪽 바퀴를 정지합니다.", "turtle_touching_color": "선택한 색깔을 컬러 센서가 감지하였으면 '참'으로 판단하고, 아니면 '거짓'으로 판단합니다.", "turtle_turn_at_intersection": "검은색 교차로에서 잠시 앞으로 이동한 후 제자리에서 왼쪽/오른쪽/뒤쪽으로 회전하고 검은색 선을 찾아 다시 이동합니다.", "turtle_turn_unit_in_place": "입력한 각도(도)/시간(초)/펄스만큼 왼쪽/오른쪽 방향으로 제자리에서 회전합니다.", "turtle_turn_unit_with_radius_in_direction": "입력한 반지름의 원을 그리면서 입력한 각도(도)/시간(초)/펄스만큼 왼쪽/오른쪽, 머리/꼬리 방향으로 회전합니다.", "turtle_value": "색깔 번호: 컬러 센서가 감지한 색깔의 번호 (값의 범위: -1 ~ 8, 초기값: -1)<br/>색깔 패턴: 컬러 센서가 감지한 색깔 패턴의 값 (값의 범위: -1 ~ 88, 초기값: -1)<br/>바닥 센서: 바닥 센서의 값 (값의 범위: 0 ~ 100, 초기값: 0)<br/>버튼: 거북이 등 버튼의 상태 값 (누르면 1, 아니면 0, 초기값: 0)<br/>x축 가속도: 가속도 센서의 X축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇이 전진하는 방향이 X축의 양수 방향입니다.<br/>y축 가속도: 가속도 센서의 Y축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 왼쪽 방향이 Y축의 양수 방향입니다.<br/>z축 가속도: 가속도 센서의 Z축 값 (값의 범위: -32768 ~ 32767, 초기값: 0) 로봇의 위쪽 방향이 Z축의 양수 방향입니다.", "neobot_sensor_value": "IN1 ~ IN3 포트 및 리모컨에서 입력되는 값 그리고 배터리 정보를 0부터 255의 숫자로 표시합니다.", "neobot_sensor_convert_scale": "선택한 포트 입력값의 변화를 특정범위의 값으로 표현범위를 조절할 수 있습니다.", "neobot_left_motor": "L모터 포트에 연결한 모터의 회전방향 및 속도를 설정합니다.", "neobot_stop_left_motor": "L모터 포트에 연결한 모터를 정지합니다.", "neobot_right_motor": "R모터 포트에 연결한 모터의 회전방향 및 속도를 설정합니다.", "neobot_stop_right_motor": "R모터 포트에 연결한 모터를 정지합니다.", "neobot_all_motor": "L모터 및 R모터 포트에 2개 모터를 연결하여 바퀴로 활용할 때 전, 후, 좌, 우 이동 방향 및 속도, 시간을 설정할 수 있습니다.", "neobot_stop_all_motor": "L모터 및 R모터에 연결한 모터를 모두 정지합니다.", "neobot_set_servo": "OUT1 ~ OUT3에 서보모터를 연결했을 때 0도 ~ 180도 범위 내에서 각도를 조절할 수 있습니다.", "neobot_set_output": "OUT1 ~ OUT3에 라이팅블록 및 전자회로를 연결했을 때 출력 전압을 설정할 수 있습니다.</br>0은 0V, 1 ~ 255는 2.4 ~ 4.96V의 전압을 나타냅니다.", "neobot_set_fnd": "FND로 0~99 까지의 숫자를 표시할 수 있습니다.", "neobot_set_fnd_off": "FND에 표시한 숫자를 끌 수 있습니다.", "neobot_play_note_for": "주파수 발진 방법을 이용해 멜로디에 반음 단위의 멜로디 음을 발생시킬 수 있습니다.", "rotate_by_angle_dropdown": "오브젝트의 방향을 입력한 각도만큼 시계방향으로 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "chocopi_control_button": "버튼이 눌리면 참이 됩니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_control_event": "버튼을 누르거나 뗄 때 처리할 엔트리 블록들을 연결합니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_control_joystick": "조이스틱 좌우, 상하, 볼륨의 값은 0~4095까지 입니다.<br/>따라서 2047 근처가 중간이 됩니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_dc_motor": "DC모터 모듈에는 직류전동기 두개를 연결 할 수 있습니다.<br/> 직류 전동기는 최대 5V로 동작하게 됩니다.<br/>값은 100이 최대(100%)이고 음수를 넣으면 반대 방향으로 회전합니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_led": "LED번호는 LED블록에 연결된 순서이고 1번부터 시작합니다.<br/>RGB값은 0~255사이의 값입니다.<br/>빨강(Red),녹색(Green), 파랑(Blue)순서로 입력합니다.<br/>밝은 LED를 직접보면 눈이 아프니까 값을 0~5정도로 씁니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_motion_photogate_event": "포토게이트는 모션블록에 연결합니다.<br/>포토게이트는 한쪽에서 나온 빛을 맞은 편의 센서가 감지하는 장치입니다.<br/>빛센서를 물체로 가리거나 치우면 시작되는 엔트리 블록을 연결합니다<br/>모션 모듈에는 포토게이트 2개를 연결할 수 있습니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_motion_photogate_status": "포토게이트는 모션블록에 연결합니다.<br/>포토게이트는 한쪽에서 나온 빛을 맞은 편의 센서가 감지하는 장치입니다.<br>물체가 빛센서를 가리면 참</b>이됩니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_motion_photogate_time": "포토게이트는 모션블록에 연결합니다.<br/>포토게이트는 한쪽에서 나온 빛을 맞은 편의 센서가 감지하는 장치입니다.<br>이 블록은 물체가 빛센서를 가리거나 벗어난 시간을 가집니다.<br/>1/10000초까지 측정할 수 있습니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_motion_value": "모션 모듈에는 3개의 적외선 센서가 있습니다.<br/>0~4095사이의 값을 가질 수 있는데 물체가 빛을 많이 반사할 수록 작은 값을 가집니다. <br/>거리를 대략적으로 측정할 수 있습니다. <br/>가속도와 각가속도 값의 범위는 -32768~32767 까지입니다.<br/>가속도를 이용해서 센서의 기울기를 측정할 수도 있습니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_sensor": "온도 값은 섭씨 온도입니다.<br/>습도 값은 백분율로 나타낸 상대습도 값입니다.<br/>빛은 로그스케일로 0~4095사이입니다.<br/>아날로그 값은 0~4095사이입니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_servo_motor": "서보모터 모듈에는 4개의 서보모터를 연결 할 수 있습니다.<br/>서보모터는 5V로 동작하게 됩니다.<br/>각도는 0~200도까지 지정할 수 있습니다.<br/>연속회전식 서보모터를 연결하면 각도에 따라 속도가 변하게됩니다.<br/>90~100 사이가 중간값입니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_touch_event": "터치 모듈에는 1~12번의 연결 패드가 있습니다. <br/>만지거나 뗄 때 처리할 엔트리 블록들을 연결합니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_touch_status": "터치 모듈의 패드를 만지면 참이됩니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "chocopi_touch_value": "터치패드에 연결된 물체의 전기용량이 커지면 값이 작아집니다.<br/>여러 명이 손잡고 만지면 더 작은 값이 됩니다.<br/>전기용량이란 물체에 전기를 띈 입자를 얼마나 가지고 있을 수 있는 지를 말합니다.<br/><br/>포트번호는 맞추지 않아도 됩니다.<br/>단, 같은 종류의 모듈을 여러 개 연결하는 경우에만 포트를 지정하면 됩니다.", "byrobot_dronefighter_controller_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_controller_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_controller_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_controller_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_controller_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_dronefighter_controller_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_controller_controller_light_manual_single_input": "<br>조종기 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다. <br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_controller_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_dronefighter_controller_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_controller_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_controller_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_controller_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_controller_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_controller_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_controller_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_dronefighter_controller_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_controller_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_dronefighter_controller_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_controller_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_dronefighter_controller_controller_userinterface_preset": "<br>조종기 설정 모드의 사용자 인터페이스를 미리 정해둔 설정으로 변경합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#설정모드</font> <font color='forestgreen'>#인터페이스</font>", "byrobot_dronefighter_controller_controller_userinterface": "<br>조종기 설정 모드의 사용자 인터페이스를 직접 지정합니다. 각 버튼 및 조이스틱 조작 시 어떤 명령을 사용할 것인지를 지정할 수 있습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#설정모드</font> <font color='forestgreen'>#인터페이스</font>", "byrobot_dronefighter_drive_drone_value_attitude": "<br>자동차의 현재 자세를 각도로 반환합니다. Roll은 좌우 기울기(-90 ~ 90), Pitch는 앞뒤 기울기(-90 ~ 90), Yaw는 회전 각도(-180 ~ 180) 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#자동차</font> <font color='forestgreen'>#자세</font>", "byrobot_dronefighter_drive_drone_value_etc": "<br>드론파이터 설정과 관련된 값들과 적외선 통신으로 받은 값을 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#자동차</font> <font color='forestgreen'>#기타</font>", "byrobot_dronefighter_drive_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_drive_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_drive_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_drive_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_drive_drone_control_car_stop": "<br>자동차 작동을 정지합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#정지</font>", "byrobot_dronefighter_drive_drone_control_double_one": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진 0 ~ 100입니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font>", "byrobot_dronefighter_drive_drone_control_double_one_delay": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진 0 ~ 100입니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_dronefighter_drive_drone_control_double": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진 0 ~ 100입니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font>", "byrobot_dronefighter_drive_drone_motor_stop": "<br>모든 모터의 작동을 정지합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터정지</font>", "byrobot_dronefighter_drive_drone_motorsingle": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_dronefighter_drive_drone_motorsingle_input": "<br>지정한 모터(1, 2, 3, 4)를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_dronefighter_drive_drone_irmessage": "<br>적외선으로 지정한 값을 보냅니다. 사용 가능한 값의 범위는 0 ~ 127입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#적외선통신</font>", "byrobot_dronefighter_drive_drone_light_manual_single_off": "<br>자동차의 모든 LED를 끕니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_dronefighter_drive_drone_light_manual_single": "<br>자동차의 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_drive_drone_light_manual_single_input": "<br>자동차 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_drive_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_dronefighter_drive_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_drive_controller_light_manual_single_input": "<br>조종기 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_drive_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_dronefighter_drive_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_drive_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_drive_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_drive_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_drive_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_drive_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_drive_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_dronefighter_drive_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_drive_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_dronefighter_drive_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_drive_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_dronefighter_flight_drone_value_attitude": "<br>드론의 현재 자세를 각도로 반환합니다. Roll은 좌우 기울기(-90 ~ 90), Pitch는 앞뒤 기울기(-90 ~ 90), Yaw는 회전 각도(-180 ~ 180) 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#자세</font>", "byrobot_dronefighter_flight_drone_value_etc": "<br>드론파이터 설정과 관련된 값들과 적외선 통신으로 받은 값을 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#기타</font>", "byrobot_dronefighter_flight_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_flight_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_flight_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_dronefighter_flight_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_dronefighter_flight_drone_control_drone_stop": "<br>드론 작동을 정지합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#정지</font>", "byrobot_dronefighter_flight_drone_control_coordinate": "<br>드론 좌표 기준을 변경합니다. 앱솔루트 모드는 이륙 시와 '방향초기화'를 했을 때 드론이 바라보는 방향을 기준으로 앞뒤좌우가 고정됩니다. 이 때에는 Yaw를 조작하여 드론이 다른 방향을 보게 하여도 처음 지정한 방향을 기준으로 앞뒤좌우로 움직입니다. 사용자가 바라보는 방향과 드론의 기준 방향이 같을 때 조작하기 편리한 장점이 있습니다. 일반 모드는 현재 드론이 바라보는 방향을 기준으로 앞뒤좌우가 결정됩니다. 드론의 움직임에 따라 앞뒤좌우가 계속 바뀌기 때문에 익숙해지기 전까지는 사용하기 어려울 수 있습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#좌표기준</font>", "byrobot_dronefighter_flight_drone_control_drone_reset_heading": "<br>드론의 방향을 초기화합니다. 앱솔루트 모드인 경우 현재 드론이 바라보는 방향을 0도로 변경합니다. 일반 모드에서는 아무런 영향이 없습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#방향초기화</font>", "byrobot_dronefighter_flight_drone_control_quad_one": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font>", "byrobot_dronefighter_flight_drone_control_quad_one_delay": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_dronefighter_flight_drone_control_quad": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font>", "byrobot_dronefighter_flight_drone_motor_stop": "<br>모든 모터의 작동을 정지합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터정지</font>", "byrobot_dronefighter_flight_drone_motorsingle": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_dronefighter_flight_drone_motorsingle_input": "<br>지정한 모터(1, 2, 3, 4)를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_dronefighter_flight_drone_irmessage": "<br>적외선으로 지정한 값을 보냅니다. 사용 가능한 값의 범위는 0 ~ 127입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#적외선통신</font>", "byrobot_dronefighter_flight_drone_light_manual_single_off": "<br>드론의 모든 LED를 끕니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_dronefighter_flight_drone_light_manual_single": "<br>드론의 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_flight_drone_light_manual_single_input": "<br>드론 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_flight_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_dronefighter_flight_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_flight_controller_light_manual_single_input": "<br>조종기 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_dronefighter_flight_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_dronefighter_flight_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_flight_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_flight_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_flight_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_dronefighter_flight_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_dronefighter_flight_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_dronefighter_flight_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_dronefighter_flight_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_flight_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_dronefighter_flight_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_dronefighter_flight_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_controller_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_controller_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_controller_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_controller_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_petrone_v2_controller_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_controller_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_controller_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_controller_controller_display_clear": "<br>조종기 OLED 화면의 선택한 영역을 지웁니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_clear_all": "<br>조종기 OLED 화면 전체를 지웁니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_circle": "<br>조종기 OLED 화면에서 지정한 위치에 원을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 반지름을 지정합니다. 원의 중심 = (x, y),<br>반지름은 원의 크기를 결정합니다.<br><br>★☆사용 가능한 값의 범위는 x값은 (-50~178), y값은 (-50~114), 반지름은 (1~200)입니다.☆★<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_line": "<br>조종기 OLED 화면에서 지정한 위치에 선을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>시작점 = (x1, y1), 끝나는점 = (x2, y2)<br>선 그리기는 시작점과 끝나는점을 이어주는 기능입니다.<br>사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_point": "<br>조종기 OLED 화면에서 지정한 위치에 점을 찍습니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다. x, y 좌표값으로 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_rect": "<br>조종기 OLED 화면에서 지정한 위치에 사각형을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 너비, 높이를 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_string": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 씁니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 글자 크기, 색을 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값은 (0~120), y값은 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_draw_string_align": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 정렬하여 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 정렬 방향, 글자 크기, 색을 지정합니다. 시작점 = (x1, y), 끝나는점 = (x2, y), 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_display_invert": "<br>조종기 OLED 화면에서 선택한 영역의 색을 반전시킵니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_controller_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_controller_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_controller_controller_light_color_rgb_input": "<br>빛의 삼원색인 Red, Green, Blue 값을 지정하여 조종기 LED의 색상을 원하는대로 만들 수 있습니다.<br>10진수(0 ~ 255) 값을 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_controller_controller_light_color_rgb_select": "<br>RGB 색지정 블록을 이용해서 만들 수 있는<br> 조종기 LED 예시입니다.<br>RGB 색지정 블록을 이용해서 멋진 색깔을<br> 다양하게 만들어보세요.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_controller_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_controller_controller_light_manual_single_input": "<br>조종기 LED를 조작하는데 사용합니다.<br>2진수(0b00100000 ~ 0b11100000), 10진수(32 ~ 224), 16진수(0x20 ~ 0xE0) 값을 사용할 수 있습니다.<br>2진수로 표현한 값에서 각각의 비트는 LED의 Red, Green, Blue 색을 선택하는 스위치 역할을 합니다.<br>밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다. <br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_controller_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_petrone_v2_controller_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_controller_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br>조이스틱 방향은 가로x세로 = 3x3 = 총9방향입니다.<br>위(왼쪽=17, 가운데=18, 오른쪽=20)<br>중간(왼쪽=33, 센터=34, 오른쪽=36)<br>아래(왼쪽=65, 가운데=66, 오른쪽=68)<br>기본값은 센터=34입니다.<br><br>조이스틱 이벤트는 값이 있을때 2, 없으면 0, 진입 1, 벗어남 3입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_controller_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_controller_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_petrone_v2_controller_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_controller_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_controller_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_drive_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_drive_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_drive_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_drive_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_petrone_v2_drive_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_drive_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_drive_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_drive_controller_display_clear": "<br>조종기 OLED 화면의 선택한 영역을 지웁니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_clear_all": "<br>조종기 OLED 화면 전체를 지웁니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_circle": "<br>조종기 OLED 화면에서 지정한 위치에 원을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 반지름을 지정합니다. 원의 중심 = (x, y),<br>반지름은 원의 크기를 결정합니다.<br><br>★☆사용 가능한 값의 범위는 x값은 (-50~178), y값은 (-50~114), 반지름은 (1~200)입니다.☆★<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_line": "<br>조종기 OLED 화면에서 지정한 위치에 선을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>시작점 = (x1, y1), 끝나는점 = (x2, y2)<br>선 그리기는 시작점과 끝나는점을 이어주는 기능입니다.<br>사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_point": "<br>조종기 OLED 화면에서 지정한 위치에 점을 찍습니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다. x, y 좌표값으로 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_rect": "<br>조종기 OLED 화면에서 지정한 위치에 사각형을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 너비, 높이를 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_string": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 씁니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 글자 크기, 색을 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값은 (0~120), y값과 높이는 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_draw_string_align": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 정렬하여 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 정렬 방향, 글자 크기, 색을 지정합니다. 시작점 = (x1, y), 끝나는점 = (x2, y), 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_display_invert": "<br>조종기 OLED 화면에서 선택한 영역의 색을 반전시킵니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_drive_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_drive_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_drive_controller_light_color_rgb_input": "<br>빛의 삼원색인 Red, Green, Blue 값을 지정하여 조종기 LED의 색상을 원하는대로 만들 수 있습니다.<br>10진수(0 ~ 255) 값을 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_controller_light_color_rgb_select": "<br>RGB 색지정 블록을 이용해서 만들 수 있는<br> 조종기 LED 예시입니다.<br>RGB 색지정 블록을 이용해서 멋진 색깔을<br> 다양하게 만들어보세요.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_controller_light_manual_single_input": "<br>조종기 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00100000 ~ 0b11100000), 10진수(32 ~ 255), 16진수(0x20 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다. <br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_petrone_v2_drive_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_drive_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br>조이스틱 방향은 가로x세로 = 3x3 = 총9방향입니다.<br>위(왼쪽=17, 가운데=18, 오른쪽=20)<br>중간(왼쪽=33, 센터=34, 오른쪽=36)<br>아래(왼쪽=65, 가운데=66, 오른쪽=68)<br>기본값은 센터=34입니다.<br><br>조이스틱 이벤트는 값이 있을때 2, 없으면 0, 진입 1, 벗어남 3입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_drive_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_drive_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_petrone_v2_drive_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_drive_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_drive_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_drive_drone_command_mode_vehicle_car": "<br>자동차 Vehicle mode를 변경합니다.<br><br>자동차 = 32, 자동차(FPV) = 33 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#Vehicle mode</font>", "byrobot_petrone_v2_drive_drone_control_car_stop": "<br>자동차 작동을 정지합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#정지</font>", "byrobot_petrone_v2_drive_drone_control_double": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진/후진 -100 ~ 100입니다. (+)값은 전진, (-)값은 후진입니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font>", "byrobot_petrone_v2_drive_drone_control_double_delay": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진/후진 -100 ~ 100입니다. (+)값은 전진, (-)값은 후진입니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_petrone_v2_drive_drone_control_double_one": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진/후진 -100 ~ 100입니다. (+)값은 전진, (-)값은 후진입니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font>", "byrobot_petrone_v2_drive_drone_control_double_one_delay": "<br>자동차 조종 값을 지정합니다. 입력 가능한 값의 범위는 방향 -100 ~ 100, 전진/후진 -100 ~ 100입니다. (+)값은 전진, (-)값은 후진입니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_petrone_v2_drive_drone_irmessage": "<br>적외선으로 지정한 값을 보냅니다. 사용 가능한 값의 범위는 0 ~ 127입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#적외선통신</font>", "byrobot_petrone_v2_drive_drone_light_color_rgb_input": "<br>빛의 삼원색인 Red, Green, Blue 값을 지정하여 자동차의 눈 또는 팔 LED의 색상을 원하는대로 만들 수 있습니다.<br>10진수(0 ~ 255) 값을 사용합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_drone_light_color_rgb_select": "<br>RGB 색지정 블록을 이용해서 만들 수 있는<br> 자동차 LED 예시입니다.<br>RGB 색지정 블록을 이용해서 멋진 색깔을<br> 다양하게 만들어보세요.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_drone_light_manual_single": "<br>자동차의 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_drone_light_manual_single_input": "<br>자동차 LED 여러 개의 밝기를 동시에 변경할 때 사용합니다. 2진수(0b00000000 ~ 0b11111111), 10진수(0 ~ 255), 16진수(0x00 ~ 0xFF) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 개별 LED를 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_drive_drone_light_manual_single_off": "<br>자동차의 모든 LED를 끕니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_petrone_v2_drive_drone_motor_stop": "<br>모든 모터의 작동을 정지합니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터정지</font>", "byrobot_petrone_v2_drive_drone_motorsingle": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 자동차의 바퀴가 움직이기 위해서는 2700 이상을 입력해야 합니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_drive_drone_motorsingle_input": "<br>지정한 모터(1, 2, 3, 4)를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 자동차의 바퀴가 움직이기 위해서는 2700 이상을 입력해야 합니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_drive_drone_motorsingle_rotation": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 1번 모터와 2번 모터는 역방향도 회전 가능하기 때문에 방향도 선택할 수 있습니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 자동차의 바퀴가 움직이기 위해서는 2700 이상을 입력해야 합니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_drive_drone_value_attitude": "<br>자동차의 현재 자세를 각도로 반환합니다. Roll은 좌우 기울기(-90 ~ 90), Pitch는 앞뒤 기울기(-90 ~ 90), Yaw는 회전 각도(-180 ~ 180) 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#자동차</font> <font color='forestgreen'>#자세</font>", "byrobot_petrone_v2_drive_drone_value_etc": "<br>페트론V2 설정과 관련된 값들과 적외선 통신으로 받은 값을 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#자동차</font> <font color='forestgreen'>#기타</font>", "byrobot_petrone_v2_drive_drone_value_imu": "<br>페트론V2 IMU센서와 관련된 값들을 반환합니다.<br>(병진운동) 가속도는 x, y, z축에 대한 중력가속도입니다. 1g = 9.8m/s^2<br>(회전운동) 각속도는 x, y, z축을 기준으로 회전하는 속력을 나타내는 벡터입니다.(pitch, roll, yaw) <br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#IMU센서</font> <font color='crimson'>#가속도</font> <font color='dodgerblue'>#병진운동</font> <font color='crimson'>#각속도</font> <font color='dodgerblue'>#회전운동</font>", "byrobot_petrone_v2_drive_drone_value_sensor": "<br>페트론V2 센서와 관련된 값들을 반환합니다.<br>온도 단위=섭씨 도, 해발고도 단위=m, image flow 단위=m, 바닥까지의 거리 단위=m<br>해발고도 값은 대기압의 영향을 받아서 오차범위가 큽니다. 바닥까지 거리의 유효 측정 거리는 2m입니다. image flow값은 일정한 속도와 높이에서 이동할 경우에 유효합니다. 이러한 센서값들을 이용하여 Petrone V2는 호버링(고도 유지) 기능을 수행합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#센서</font> <font color='crimson'>#온도</font> <font color='dodgerblue'>#해발고도</font> <font color='forestgreen'>#image flow</font> <font color='crimson'>#range</font> <font color='dodgerblue'>#대기압</font> <font color='forestgreen'>#호버링</font>", "byrobot_petrone_v2_flight_controller_buzzer_hz": "<br>지정한 주파수의 소리를 계속해서 연주합니다(최대 60초). 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_flight_controller_buzzer_hz_delay": "<br>지정한 주파수의 소리를 지정한 시간동안 연주합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_flight_controller_buzzer_hz_reserve": "<br>지정한 주파수의 소리를 지정한 시간동안 연주하도록 예약합니다. 권장 사용 범위는 250 ~ 8000 입니다. 4옥타브를 기준으로 도(261), 도#(277), 레(293), 레#(311), 미(329), 파(349), 파#(370), 솔(392), 솔#(415), 라(440), 라#(466), 시(493)입니다. 여기에서 한 옥타브를 올라갈 때마다 주파수 값이 두 배가 됩니다. 한 옥타브를 내려갈 때에는 주파수 값이 절반이 됩니다. 예를 들면 3옥타브의 도는 130.8128Hz, 4옥타브의 도는 261.6256Hz, 5옥타브의 도는 523.2511Hz 입니다. 이 블럭은 소리가 나도록 예약하고, 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#주파수</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_flight_controller_buzzer_off": "<br>버저 작동을 중단합니다. 예약된 소리가 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저끄기</font>", "byrobot_petrone_v2_flight_controller_buzzer_scale": "<br>지정한 옥타브의 음을 계속해서 연주합니다(최대 60초). 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭은 연주 명령을 실행 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font>", "byrobot_petrone_v2_flight_controller_buzzer_scale_delay": "<br>지정한 옥타브의 음을 지정한 시간동안 연주합니다. 이 블럭을 만났을 경우 소리가 켜져있거나 예약된 소리가 있다면 모두 삭제합니다. 이 블럭을 사용하면 소리가 끝날때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#즉시</font> <font color='blueviolet'>#시간지연</font>", "byrobot_petrone_v2_flight_controller_buzzer_scale_reserve": "<br>지정한 옥타브의 음을 지정한 시간동안 연주하도록 예약합니다. 이 블럭은 소리가 나도록 예약하고 바로 다음 블럭으로 넘어갑니다. 예약은 최대 12개까지 누적할 수 있습니다. 이 블럭은 주로 버저 소리와 함께 다른 행동을 동시에 할 때 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#버저</font> <font color='forestgreen'>#음계</font> <font color='peru'>#예약</font>", "byrobot_petrone_v2_flight_controller_display_clear": "<br>조종기 OLED 화면의 선택한 영역을 지웁니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_clear_all": "<br>조종기 OLED 화면 전체를 지웁니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_circle": "<br>조종기 OLED 화면에서 지정한 위치에 원을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 반지름을 지정합니다. 원의 중심 = (x, y),<br>반지름은 원의 크기를 결정합니다.<br><br>★☆사용 가능한 값의 범위는 x값은 (-50~178), y값은 (-50~114), 반지름은 (1~200)입니다.☆★<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_line": "<br>조종기 OLED 화면에서 지정한 위치에 선을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>시작점 = (x1, y1), 끝나는점 = (x2, y2)<br>선 그리기는 시작점과 끝나는점을 이어주는 기능입니다.<br>사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_point": "<br>조종기 OLED 화면에서 지정한 위치에 점을 찍습니다. 흰색/검은색 중에서 원하는 색을 선택할 수 있습니다. x, y 좌표값으로 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_rect": "<br>조종기 OLED 화면에서 지정한 위치에 사각형을 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>x, y 좌표값과 너비, 높이를 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_string": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 씁니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 글자 크기, 색을 지정합니다. 시작점 = (x, y), 사용 가능한 값의 범위는 x값은 (0~120), y값과 높이는 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_draw_string_align": "<br>조종기 OLED 화면에서 지정한 위치에 문자열을 정렬하여 그립니다.<br><br>☆★ (x, y)좌표에 관한 설명은 [조종기 화면 점 찍기]블럭을 참조해주세요. ★☆<br><br>글자 입력은 영문자 알파벳 대문자, 소문자와 숫자, 공백(space), 특수문자만 가능합니다.(한글은 아직 지원되지 않습니다.)<br>x, y 좌표값과 정렬 방향, 글자 크기, 색을 지정합니다. 시작점 = (x1, y), 끝나는점 = (x2, y), 사용 가능한 값의 범위는 x값은 (0~128), y값은 (0~60)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_display_invert": "<br>조종기 OLED 화면에서 선택한 영역의 색을 반전시킵니다. x, y 좌표값과 너비, 높이를 지정합니다. 좌표(x, y) = (가로, 세로) 화면상의 위치입니다. 사용 가능한 값의 범위는 x값과 너비는 (0~128), y값과 높이는 (0~64)입니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#Display</font>", "byrobot_petrone_v2_flight_controller_if_button_press": "<br>지정한 조종기의 버튼이 눌러졌을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_flight_controller_if_joystick_direction": "<br>조종기의 조이스틱을 지정한 방향으로 움직였을 때 true를 반환합니다.<br><br><font color='crimson'>#조건</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_flight_controller_light_color_rgb_input": "<br>빛의 삼원색인 Red, Green, Blue 값을 지정하여 조종기 LED의 색상을 원하는대로 만들 수 있습니다.<br>10진수(0 ~ 255) 값을 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_controller_light_color_rgb_select": "<br>RGB 색지정 블록을 이용해서 만들 수 있는<br> 조종기 LED 예시입니다.<br>RGB 색지정 블록을 이용해서 멋진 색깔을<br> 다양하게 만들어보세요.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_controller_light_manual_single": "<br>조종기 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_controller_light_manual_single_input": "<br>조종기 LED를 조작하는데 사용합니다.<br>2진수(0b00100000 ~ 0b11100000), 10진수(32 ~ 224), 16진수(0x20 ~ 0xE0) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 LED의 Red, Green, Blue 색을 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다. <br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_controller_light_manual_single_off": "<br>조종기의 모든 LED를 끕니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_petrone_v2_flight_controller_value_button": "<br>조종기에서 눌러진 버튼과 관련된 이벤트를 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#버튼</font>", "byrobot_petrone_v2_flight_controller_value_joystick": "<br>조종기의 조이스틱과 관련된 입력 값을 반환합니다. 각 축의 범위는 -100 ~ 100 입니다.<br><br>조이스틱 방향은 가로x세로 = 3x3 = 총9방향입니다.<br>위(왼쪽=17, 가운데=18, 오른쪽=20)<br>중간(왼쪽=33, 센터=34, 오른쪽=36)<br>아래(왼쪽=65, 가운데=66, 오른쪽=68)<br>기본값은 센터=34입니다.<br><br>조이스틱 이벤트는 값이 있을때 2, 없으면 0, 진입 1, 벗어남 3입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#조종기</font> <font color='forestgreen'>#조이스틱</font>", "byrobot_petrone_v2_flight_controller_vibrator_delay": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복합니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_flight_controller_vibrator_off": "<br>진동을 끕니다. 예약된 진동이 있다면 모두 삭제합니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동끄기</font>", "byrobot_petrone_v2_flight_controller_vibrator_on_delay": "<br>진동을 지정한 시간동안 켭니다. 이 블럭을 만났을 경우 진동이 켜져있거나 예약된 진동이 있다면 모두 삭제합니다. 이 블럭은 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#즉시</font> <font color='peru'>#시간지연</font>", "byrobot_petrone_v2_flight_controller_vibrator_on_reserve": "<br>진동을 지정한 시간동안 켜는 것을 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_flight_controller_vibrator_reserve": "<br>진동을 지정한 시간동안 켜고 끄는 것을 지정한 시간동안 반복하도록 예약합니다. 이 블럭은 명령을 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#조종기</font> <font color='dodgerblue'>#진동</font> <font color='forestgreen'>#예약</font>", "byrobot_petrone_v2_flight_drone_command_mode_vehicle_drone": "<br>드론 Vehicle mode를 변경합니다.<br><br>드론(가드 포함) = 16, 드론(가드 없음) = 17, 드론(FPV) = 18 입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#Vehicle mode</font>", "byrobot_petrone_v2_flight_drone_control_coordinate": "<br>드론 좌표 기준을 변경합니다. Headless mode 선택을 on으로 하면 이륙 시와 '방향초기화'를 했을 때 드론이 바라보는 방향을 기준으로 앞뒤좌우가 고정됩니다. 이 때에는 Yaw를 조작하여 드론이 다른 방향을 보게 하여도 처음 지정한 방향을 기준으로 앞뒤좌우로 움직입니다. 사용자가 바라보는 방향과 드론의 기준 방향이 같을 때 조작하기 편리한 장점이 있습니다.<br>Headless mode를 off로 선택하면 현재 드론이 바라보는 방향을 기준으로 앞뒤좌우가 결정됩니다. 드론의 움직임에 따라 앞뒤좌우가 계속 바뀌기 때문에 익숙해지기 전까지는 사용하기 어려울 수 있습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#좌표기준</font>", "byrobot_petrone_v2_flight_drone_control_drone_landing": "<br>드론을 착륙시킵니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#착륙</font>", "byrobot_petrone_v2_flight_drone_control_drone_reset_heading": "<br>드론의 방향을 초기화합니다. 앱솔루트 모드인 경우 현재 드론이 바라보는 방향을 0도로 변경합니다. 일반 모드에서는 아무런 영향이 없습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#방향초기화</font>", "byrobot_petrone_v2_flight_drone_control_drone_stop": "<br>드론 작동을 정지합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#정지</font>", "byrobot_petrone_v2_flight_drone_control_drone_takeoff": "<br>드론을 이륙시킵니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#이륙</font>", "byrobot_petrone_v2_flight_drone_control_quad": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font>", "byrobot_petrone_v2_flight_drone_control_quad_delay": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_petrone_v2_flight_drone_control_quad_one": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 명령 전달 후 바로 다음 블럭으로 넘어갑니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font>", "byrobot_petrone_v2_flight_drone_control_quad_one_delay": "<br>드론 조종 값을 지정합니다. 입력 가능한 값의 범위는 -100 ~ 100입니다. 정지 상태에서 Throttle 값을 50이상으로 지정하면 드론이 이륙합니다. 지정한 시간이 지나면 해당 조종 값을 0으로 변경합니다. 지정한 시간이 끝날 때까지 다음 블럭으로 넘어가지 않습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#조종</font> <font color='forestgreen'>#시간지연</font>", "byrobot_petrone_v2_flight_drone_irmessage": "<br>적외선으로 지정한 값을 보냅니다. 사용 가능한 값의 범위는 -2147483647 ~ 2147483647입니다.수신 방향이 추가되었습니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#적외선통신</font>", "byrobot_petrone_v2_flight_drone_light_color_rgb_input": "<br>빛의 삼원색인 Red, Green, Blue 값을 지정하여 드론의 눈 또는 팔 LED의 색상을 원하는대로 만들 수 있습니다.<br>10진수(0 ~ 255) 값을 사용합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_drone_light_color_rgb_select": "<br>RGB 색지정 블록을 이용해서 만들 수 있는<br> 드론 LED 예시입니다.<br>RGB 색지정 블록을 이용해서 멋진 색깔을<br> 다양하게 만들어보세요.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_drone_light_manual_single": "<br>드론의 LED를 조작하는데 사용합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_drone_light_manual_single_input": "<br>드론 LED를 조작하는데 사용합니다.<br>2진수(0b00000100 ~ 0b11111100), 10진수(4 ~ 252), 16진수(0x04 ~ 0xFC) 값을 사용할 수 있습니다. 2진수로 표현한 값에서 각각의 비트는 눈과 팔 LED의 Red, Green, Blue 색을 선택하는 스위치 역할을 합니다. 밝기 값은 0 ~ 255 사이의 값을 사용할 수 있습니다. 값이 커질수록 더 밝아집니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED제어</font>", "byrobot_petrone_v2_flight_drone_light_manual_single_off": "<br>드론의 모든 LED를 끕니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#LED끄기</font>", "byrobot_petrone_v2_flight_drone_motor_stop": "<br>모든 모터의 작동을 정지합니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터정지</font>", "byrobot_petrone_v2_flight_drone_motorsingle": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_flight_drone_motorsingle_input": "<br>지정한 모터(1, 2, 3, 4)를 원하는 빠르기로 회전할 때 사용합니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#드론</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_flight_drone_motorsingle_rotation": "<br>지정한 모터를 원하는 빠르기로 회전할 때 사용합니다. 1번 모터와 2번 모터는 역방향도 회전 가능하기 때문에 방향도 선택할 수 있습니다. 사용 가능한 값의 범위는 0 ~ 4000입니다. 모터의 순서는 '왼쪽 앞', '오른쪽 앞', '오른쪽 뒤', '왼쪽 뒤' 입니다.<br><br><font color='crimson'>#자동차</font> <font color='dodgerblue'>#모터제어</font>", "byrobot_petrone_v2_flight_drone_value_attitude": "<br>드론의 현재 자세를 각도로 반환합니다. Roll은 좌우 기울기(-90 ~ 90), Pitch는 앞뒤 기울기(-90 ~ 90), Yaw는 회전 각도(-180 ~ 180) 입니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#자세</font>", "byrobot_petrone_v2_flight_drone_value_etc": "<br>페트론V2 설정과 관련된 값들과 적외선 통신으로 받은 값을 반환합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#기타</font>", "byrobot_petrone_v2_flight_drone_value_imu": "<br>페트론V2 IMU센서와 관련된 값들을 반환합니다.<br>(병진운동) 가속도는 x, y, z축에 대한 중력가속도입니다. 1g = 9.8m/s^2<br>(회전운동) 각속도는 x, y, z축을 기준으로 회전하는 속력을 나타내는 벡터입니다.(pitch, roll, yaw) <br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#IMU센서</font> <font color='crimson'>#가속도</font> <font color='dodgerblue'>#병진운동</font> <font color='crimson'>#각속도</font> <font color='dodgerblue'>#회전운동</font>", "byrobot_petrone_v2_flight_drone_value_sensor": "<br>페트론V2 센서와 관련된 값들을 반환합니다.<br>온도 단위=섭씨 도, 해발고도 단위=m, image flow 단위=m, 바닥까지의 거리 단위=m<br>해발고도 값은 대기압의 영향을 받아서 오차범위가 큽니다. 바닥까지 거리의 유효 측정 거리는 2m입니다. image flow값은 일정한 속도와 높이에서 이동할 경우에 유효합니다. 이러한 센서값들을 이용하여 Petrone V2는 호버링(고도 유지) 기능을 수행합니다.<br><br><font color='crimson'>#값</font> <font color='dodgerblue'>#드론</font> <font color='forestgreen'>#센서</font> <font color='crimson'>#온도</font> <font color='dodgerblue'>#해발고도</font> <font color='forestgreen'>#image flow</font> <font color='crimson'>#range</font> <font color='dodgerblue'>#대기압</font> <font color='forestgreen'>#호버링</font>", "boolean_and_or": "그리고 : 두 판단이 모두 참인 경우 ‘참’으로 판단합니다.<br>또는 : 두 판단 중 하나라도 참이 있는 경우 ‘참’으로 판단합니다." }; Lang.Category = { "entrybot_friends": "엔트리봇 친구들", "people": "사람", "animal": "동물", "animal_flying": "하늘", "animal_land": "땅", "animal_water": "물", "animal_others": "기타", "plant": "식물", "plant_flower": "꽃", "plant_grass": "풀", "plant_tree": "나무", "plant_others": "기타", "vehicles": "탈것", "vehicles_flying": "하늘", "vehicles_land": "땅", "vehicles_water": "물", "vehicles_others": "기타", "architect": "건물", "architect_building": "건축물", "architect_monument": "기념물", "architect_others": "기타", "food": "음식", "food_vegetables": "과일/채소", "food_meat": "고기", "food_drink": "음료", "food_others": "기타", "environment": "환경", "environment_nature": "자연", "environment_space": "우주", "environment_others": "기타", "stuff": "물건", "stuff_living": "생활", "stuff_hobby": "취미", "stuff_others": "기타", "fantasy": "판타지", "interface": "인터페이스", "background": "배경", "background_outdoor": "실외", "background_indoor": "실내", "background_nature": "자연", "background_others": "기타" }; Lang.Device = { "arduino": "아두이노", "byrobot_dronefighter_controller": "바이로봇 드론파이터 컨트롤러", "byrobot_dronefighter_drive": "바이로봇 드론파이터 자동차", "byrobot_dronefighter_flight": "바이로봇 드론파이터 드론", "byrobot_petrone_v2_controller": "바이로봇 페트론V2 조종기", "byrobot_petrone_v2_drive": "바이로봇 페트론V2 자동차", "byrobot_petrone_v2_flight": "바이로봇 페트론V2 드론", "hamster": "햄스터", "roboid": "로보이드", "turtle": "거북이", "albert": "알버트", "robotis_carCont": "로보티즈 자동차 로봇", "robotis_openCM70": "로보티즈 IoT", "sensorBoard": "엔트리 센서보드", "trueRobot": "뚜루뚜루", "CODEino": "코드이노", "bitbrick": "비트브릭", "bitBlock": "비트블록", "xbot_epor_edge": "엑스봇", "dplay": "디플레이", "iboard": "아이보드", "nemoino": "네모이노", "ev3": "EV3", "robotori": "로보토리", "smartBoard": "스마트보드", "chocopi": "초코파이보드", "rokoboard": "로코보드", "altino": "알티노" }; Lang.General = { "turn_on": "켜기", "turn_off": "끄기", "left": "왼쪽", "right": "오른쪽", "param_string": "문자값", "both": "양쪽", "transparent": "투명", "black": "검은색", "brown": "갈색", "red": "빨간색", "yellow": "노란색", "green": "초록색", "skyblue": "하늘색", "blue": "파란색", "purple": "보라색", "white": "하얀색", "note_c": "도", "note_d": "레", "note_e": "미", "note_f": "파", "note_g": "솔", "note_a": "라", "note_b": "시", "questions": "문제", "clock": "시계", "counter_clock": "반시계", "font_size": "글자 크기", "second": "초", "alert_title": "알림", "confirm_title": "확인", "update_title": "업데이트 알림", "recent_download": "최신 버전 다운로드", "recent_download2": "최신버전 다운로드", "latest_version": "최신 버전입니다." }; Lang.Fonts = { "batang": "바탕체", "myeongjo": "명조체", "gothic": "고딕체", "pen_script": "필기체", "jeju_hallasan": "한라산체", "gothic_coding": "코딩고딕체" }; Lang.Hw = { "note": "음표", "leftWheel": "왼쪽 바퀴", "rightWheel": "오른쪽 바퀴", "leftEye": "왼쪽 눈", "rightEye": "오른쪽 눈", "led": "불빛", "led_en": "LED", "body": "몸통", "front": "앞쪽", "port_en": "", "port_ko": "번 포트", "sensor": "센서", "light": "빛", "temp": "온도", "switch_": "스위치", "right_ko": "오른쪽", "right_en": "", "left_ko": "왼쪽", "left_en": "", "up_ko": "위쪽", "up_en": "", "down_ko": "아래쪽", "down_en": "", "output": "출력", "left": "왼쪽", "right": "오른쪽", "sub": "서보", "motor": "모터", "": "", "buzzer": "버저", "IR": "적외선", "acceleration": "가속", "analog": "아날로그", "angular_acceleration": "각가속", "button": "버튼", "humidity": "습도", "joystick": "조이스틱", "port": "포트", "potentiometer": "포텐시오미터", "servo": "서보" }; Lang.template = { "albert_hand_found": "손 찾음?", "albert_is_oid_value": " %1 OID 값이 %2 인가? ", "albert_value": "%1", "albert_move_forward_for_secs": "앞으로 %1 초 이동하기 %2", "albert_move_backward_for_secs": "뒤로 %1 초 이동하기 %2", "albert_turn_for_secs": "%1 으로 %2 초 돌기 %3", "albert_change_both_wheels_by": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 만큼 바꾸기 %3", "albert_set_both_wheels_to": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 (으)로 정하기 %3", "albert_change_wheel_by": "%1 바퀴 %2 만큼 바꾸기 %3", "albert_set_wheel_to": "%1 바퀴 %2 (으)로 정하기 %3", "albert_stop": "정지하기 %1", "albert_set_pad_size_to": "말판 크기를 폭 %1 높이 %2 (으)로 정하기 %3", "albert_move_to_x_y_on_board": "밑판 x: %1 y: %2 위치로 이동하기 %3", "albert_set_orientation_on_board": "말판 %1도 방향으로 바라보기 %2", "albert_set_eye_to": "%1 눈을 %2 으로 정하기 %3", "albert_clear_eye": "%1 눈 끄기 %2", "albert_body_led": "몸통 LED %1 %2", "albert_front_led": "앞쪽 LED %1 %2", "albert_beep": "삐 소리내기 %1", "albert_change_buzzer_by": "버저 음을 %1 만큼 바꾸기 %2", "albert_set_buzzer_to": "버저 음을 %1 (으)로 정하기 %2", "albert_clear_buzzer": "버저 끄기 %1", "albert_play_note_for": "%1 %2 음을 %3 박자 연주하기 %4", "albert_rest_for": "%1 박자 쉬기 %2", "albert_change_tempo_by": "연주 속도를 %1 만큼 바꾸기 %2", "albert_set_tempo_to": "연주 속도를 %1 BPM으로 정하기 %2", "albert_move_forward": "앞으로 이동하기 %1", "albert_move_backward": "뒤로 이동하기 %1", "albert_turn_around": "%1 으로 돌기 %2", "albert_set_led_to": "%1 %2 으로 정하기 %3", "albert_clear_led": "%1 %2", "albert_change_wheels_by": "%1 %2 %3", "albert_set_wheels_to": "%1 %2 %3", "arduino_text": "%1", "arduino_send": "신호 %1 보내기", "arduino_get_number": "신호 %1 의 숫자 결과값", "arduino_get_string": "신호 %1 의 글자 결과값", "arduino_get_sensor_number": "%1 ", "arduino_get_port_number": "%1 ", "arduino_get_digital_toggle": "%1 ", "arduino_get_pwm_port_number": "%1 ", "arduino_get_number_sensor_value": "아날로그 %1 번 센서값 ", "arduino_ext_get_analog_value": "아날로그 %1 번 센서값", "arduino_ext_get_analog_value_map": "%1 의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼값", "arduino_ext_get_ultrasonic_value": "울트라소닉 Trig %1 Echo %2 센서값", "arduino_ext_toggle_led": "디지털 %1 번 핀 %2 %3", "arduino_ext_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "arduino_ext_set_tone": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "arduino_ext_set_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "arduino_ext_get_digital": "디지털 %1 번 센서값", "blacksmith_get_analog_value": "아날로그 %1 번 핀 센서 값", "blacksmith_get_analog_mapping": "아날로그 %1 번 핀 센서 값의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼 값", "blacksmith_get_digital_bluetooth": "블루투스 RX 2 핀 데이터 값", "blacksmith_get_digital_ultrasonic": "초음파 Trig %1 핀 Echo %2 핀 센서 값", "blacksmith_get_digital_toggle": "디지털 %1 번 핀 센서 값", "blacksmith_set_digital_toggle": "디지털 %1 번 핀 %2 %3", "blacksmith_set_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "blacksmith_set_digital_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "blacksmith_set_digital_buzzer": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "blacksmith_set_digital_lcd": "LCD화면 %1 줄에 %2 나타내기 %3", "blacksmith_set_digital_bluetooth": "블루투스 TX 3 핀에 %1 데이터 보내기 %2", "byrobot_dronefighter_controller_controller_value_button": "%1", "byrobot_dronefighter_controller_controller_value_joystick": "%1", "byrobot_dronefighter_controller_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_dronefighter_controller_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_dronefighter_controller_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_dronefighter_controller_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_dronefighter_controller_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_dronefighter_controller_controller_buzzer_off": "버저 끄기 %1", "byrobot_dronefighter_controller_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_dronefighter_controller_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_dronefighter_controller_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_dronefighter_controller_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_dronefighter_controller_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_dronefighter_controller_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_dronefighter_controller_controller_vibrator_off": "진동 끄기 %1", "byrobot_dronefighter_controller_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_dronefighter_controller_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_dronefighter_controller_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_dronefighter_controller_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_dronefighter_controller_controller_userinterface_preset": "조종기 설정 모드 사용자 인터페이스를 %1(으)로 변경%2", "byrobot_dronefighter_controller_controller_userinterface": "조종기 설정 모드에서 %1 %2 실행 %3", "byrobot_dronefighter_drive_drone_value_attitude": "%1", "byrobot_dronefighter_drive_drone_value_etc": "%1", "byrobot_dronefighter_drive_controller_value_button": "%1", "byrobot_dronefighter_drive_controller_value_joystick": "%1", "byrobot_dronefighter_drive_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_dronefighter_drive_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_dronefighter_drive_drone_control_car_stop": "자동차 정지 %1", "byrobot_dronefighter_drive_drone_control_double_one": "자동차를 %1 %2% 정하기 %3", "byrobot_dronefighter_drive_drone_control_double_one_delay": "자동차를 %1 %2% %3 초 실행 %4", "byrobot_dronefighter_drive_drone_control_double": "자동차를 방향 %1%, 전진 %2% 정하기 %3", "byrobot_dronefighter_drive_drone_motor_stop": "모터 정지 %1", "byrobot_dronefighter_drive_drone_motorsingle": "%1 번 모터를 %2 (으)로 회전 %3", "byrobot_dronefighter_drive_drone_motorsingle_input": "%1 번 모터를 %2 (으)로 회전 %3", "byrobot_dronefighter_drive_drone_irmessage": "적외선으로 %1 값 보내기 %2", "byrobot_dronefighter_drive_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_dronefighter_drive_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_dronefighter_drive_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_dronefighter_drive_drone_light_manual_single_off": "자동차 LED 끄기 %1", "byrobot_dronefighter_drive_drone_light_manual_single": "자동차 LED %1 %2 %3", "byrobot_dronefighter_drive_drone_light_manual_single_input": "자동차 LED %1 밝기 %2 %3", "byrobot_dronefighter_drive_controller_buzzer_off": "버저 끄기 %1", "byrobot_dronefighter_drive_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_dronefighter_drive_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_dronefighter_drive_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_dronefighter_drive_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_dronefighter_drive_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_dronefighter_drive_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_dronefighter_drive_controller_vibrator_off": "진동 끄기 %1", "byrobot_dronefighter_drive_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_dronefighter_drive_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_dronefighter_drive_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_dronefighter_drive_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_dronefighter_flight_drone_value_attitude": "%1", "byrobot_dronefighter_flight_drone_value_etc": "%1", "byrobot_dronefighter_flight_controller_value_button": "%1", "byrobot_dronefighter_flight_controller_value_joystick": "%1", "byrobot_dronefighter_flight_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_dronefighter_flight_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_dronefighter_flight_drone_control_drone_stop": "드론 정지 %1", "byrobot_dronefighter_flight_drone_control_coordinate": "드론 좌표 기준을 %1로 정하기 %2", "byrobot_dronefighter_flight_drone_control_drone_reset_heading": "드론 방향 초기화 %1", "byrobot_dronefighter_flight_drone_control_quad_one": "드론 %1 %2% 정하기 %3", "byrobot_dronefighter_flight_drone_control_quad_one_delay": "드론 %1 %2% %3 초 실행 %4", "byrobot_dronefighter_flight_drone_control_quad": "드론 Roll %1%, Pitch %2%, Yaw %3%, Throttle %4% 정하기 %5", "byrobot_dronefighter_flight_drone_motor_stop": "모터 정지 %1", "byrobot_dronefighter_flight_drone_motorsingle": "%1 번 모터를 %2 (으)로 회전 %3", "byrobot_dronefighter_flight_drone_motorsingle_input": "%1 번 모터를 %2 (으)로 회전 %3", "byrobot_dronefighter_flight_drone_irmessage": "적외선으로 %1 값 보내기 %2", "byrobot_dronefighter_flight_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_dronefighter_flight_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_dronefighter_flight_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_dronefighter_flight_drone_light_manual_single_off": "드론 LED 끄기 %1", "byrobot_dronefighter_flight_drone_light_manual_single": "드론 LED %1 %2 %3", "byrobot_dronefighter_flight_drone_light_manual_single_input": "드론 LED %1 밝기 %2 %3", "byrobot_dronefighter_flight_controller_buzzer_off": "버저 끄기 %1", "byrobot_dronefighter_flight_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_dronefighter_flight_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_dronefighter_flight_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_dronefighter_flight_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_dronefighter_flight_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_dronefighter_flight_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_dronefighter_flight_controller_vibrator_off": "진동 끄기 %1", "byrobot_dronefighter_flight_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_dronefighter_flight_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_dronefighter_flight_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_dronefighter_flight_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_petrone_v2_controller_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_petrone_v2_controller_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_petrone_v2_controller_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_petrone_v2_controller_controller_buzzer_off": "버저 끄기 %1", "byrobot_petrone_v2_controller_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_petrone_v2_controller_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_petrone_v2_controller_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_petrone_v2_controller_controller_display_clear": "지우기 x %1, y %2, 너비 %3, 높이 %4 %5 %6", "byrobot_petrone_v2_controller_controller_display_clear_all": "조종기 화면 전체 지우기%1 %2", "byrobot_petrone_v2_controller_controller_display_draw_circle": "원 x %1, y %2, 반지름 %3 %4 %5 %6", "byrobot_petrone_v2_controller_controller_display_draw_line": "선 x1 %1, y1 %2, x2 %3, y2 %4 %5 %6 %7", "byrobot_petrone_v2_controller_controller_display_draw_point": "점 그리기 x %1, y %2 %3 %4", "byrobot_petrone_v2_controller_controller_display_draw_rect": "사각형 x %1, y %2, 너비 %3, 높이 %4 %5 %6 %7 %8", "byrobot_petrone_v2_controller_controller_display_draw_string": "문자열 x %1, y %2 %3 %4 입력 %5 %6", "byrobot_petrone_v2_controller_controller_display_draw_string_align": "문자열 정렬 x1 %1, x2 %2, y %3 %4 %5 %6 입력 %7 %8", "byrobot_petrone_v2_controller_controller_display_invert": "색반전 x %1, y %2, 너비 %3, 높이 %4 %5", "byrobot_petrone_v2_controller_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_petrone_v2_controller_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_petrone_v2_controller_controller_light_color_rgb_input": "조종기 LED 색지정 R %1, G %2, B %3 %4 %5", "byrobot_petrone_v2_controller_controller_light_color_rgb_select": "조종기 LED의 RGB 조합 예시 %1 %2 %3", "byrobot_petrone_v2_controller_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_petrone_v2_controller_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_petrone_v2_controller_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_petrone_v2_controller_controller_value_button": "%1", "byrobot_petrone_v2_controller_controller_value_joystick": "%1", "byrobot_petrone_v2_controller_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_petrone_v2_controller_controller_vibrator_off": "진동 끄기 %1", "byrobot_petrone_v2_controller_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_petrone_v2_controller_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_petrone_v2_controller_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_petrone_v2_drive_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_petrone_v2_drive_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_petrone_v2_drive_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_petrone_v2_drive_controller_buzzer_off": "버저 끄기 %1", "byrobot_petrone_v2_drive_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_petrone_v2_drive_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_petrone_v2_drive_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_petrone_v2_drive_controller_display_clear": "지우기 x %1, y %2, 너비 %3, 높이 %4 %5 %6", "byrobot_petrone_v2_drive_controller_display_clear_all": "조종기 화면 전체 지우기%1 %2", "byrobot_petrone_v2_drive_controller_display_draw_circle": "원 x %1, y %2, 반지름 %3 %4 %5 %6", "byrobot_petrone_v2_drive_controller_display_draw_line": "선 x1 %1, y1 %2, x2 %3, y2 %4 %5 %6 %7", "byrobot_petrone_v2_drive_controller_display_draw_point": "점 그리기 x %1, y %2 %3 %4", "byrobot_petrone_v2_drive_controller_display_draw_rect": "사각형 x %1, y %2, 너비 %3, 높이 %4 %5 %6 %7 %8", "byrobot_petrone_v2_drive_controller_display_draw_string": "문자열 x %1, y %2 %3 %4 입력 %5 %6", "byrobot_petrone_v2_drive_controller_display_draw_string_align": "문자열 정렬 x1 %1, x2 %2, y %3 %4 %5 %6 입력 %7 %8", "byrobot_petrone_v2_drive_controller_display_invert": "색반전 x %1, y %2, 너비 %3, 높이 %4 %5", "byrobot_petrone_v2_drive_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_petrone_v2_drive_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_petrone_v2_drive_controller_light_color_rgb_input": "조종기 LED 색지정 R %1, G %2, B %3 %4 %5", "byrobot_petrone_v2_drive_controller_light_color_rgb_select": "조종기 LED의 RGB 조합 예시 %1 %2 %3", "byrobot_petrone_v2_drive_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_petrone_v2_drive_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_petrone_v2_drive_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_petrone_v2_drive_controller_value_button": "%1", "byrobot_petrone_v2_drive_controller_value_joystick": "%1", "byrobot_petrone_v2_drive_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_petrone_v2_drive_controller_vibrator_off": "진동 끄기 %1", "byrobot_petrone_v2_drive_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_petrone_v2_drive_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_petrone_v2_drive_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_petrone_v2_drive_drone_command_mode_vehicle_car": "Vehicle mode %1 선택 %2", "byrobot_petrone_v2_drive_drone_control_car_stop": "자동차 정지 %1", "byrobot_petrone_v2_drive_drone_control_double": "자동차를 방향 %1%, 전진/후진 %2% 정하기 %3", "byrobot_petrone_v2_drive_drone_control_double_delay": "자동차를 방향 %1%, 전진/후진 %2% %3 초 실행 %4", "byrobot_petrone_v2_drive_drone_control_double_one": "자동차를 %1 %2% 정하기 %3", "byrobot_petrone_v2_drive_drone_control_double_one_delay": "자동차를 %1 %2% %3 초 실행 %4", "byrobot_petrone_v2_drive_drone_irmessage": "적외선으로 %1 값 보내기 %2", "byrobot_petrone_v2_drive_drone_light_color_rgb_input": "자동차 %1 LED 색지정 R %2, G %3, B %4 %5 %6", "byrobot_petrone_v2_drive_drone_light_color_rgb_select": "자동차 %1 LED의 RGB 조합 예시 %2 %3 %4", "byrobot_petrone_v2_drive_drone_light_manual_single": "자동차 LED %1 %2 %3", "byrobot_petrone_v2_drive_drone_light_manual_single_input": "자동차 LED %1 밝기 %2 %3", "byrobot_petrone_v2_drive_drone_light_manual_single_off": "자동차 LED 끄기 %1", "byrobot_petrone_v2_drive_drone_motor_stop": "모터 정지 %1", "byrobot_petrone_v2_drive_drone_motorsingle": "%1번 모터를 %2(으)로 회전 %3", "byrobot_petrone_v2_drive_drone_motorsingle_input": "%1번 모터를 %2(으)로 회전 %3", "byrobot_petrone_v2_drive_drone_motorsingle_rotation": "%1번 모터를 %2으로 %3(으)로 회전 %4", "byrobot_petrone_v2_drive_drone_value_attitude": "%1", "byrobot_petrone_v2_drive_drone_value_etc": "%1", "byrobot_petrone_v2_drive_drone_value_imu": "%1", "byrobot_petrone_v2_drive_drone_value_sensor": "%1", "byrobot_petrone_v2_flight_controller_buzzer_hz": "%1 Hz 소리를 연주 %2", "byrobot_petrone_v2_flight_controller_buzzer_hz_delay": "%1 Hz 소리를 %2 초 연주 %3", "byrobot_petrone_v2_flight_controller_buzzer_hz_reserve": "%1 Hz 소리를 %2 초 예약 %3", "byrobot_petrone_v2_flight_controller_buzzer_off": "버저 끄기 %1", "byrobot_petrone_v2_flight_controller_buzzer_scale": "%1 옥타브 %2 을(를) 연주 %3", "byrobot_petrone_v2_flight_controller_buzzer_scale_delay": "%1 옥타브 %2 을(를) %3 초 연주 %4", "byrobot_petrone_v2_flight_controller_buzzer_scale_reserve": "%1 옥타브 %2 을(를) %3 초 예약 %4", "byrobot_petrone_v2_flight_controller_display_clear": "지우기 x %1, y %2, 너비 %3, 높이 %4 %5 %6", "byrobot_petrone_v2_flight_controller_display_clear_all": "조종기 화면 전체 지우기%1 %2", "byrobot_petrone_v2_flight_controller_display_draw_circle": "원 x %1, y %2, 반지름 %3 %4 %5 %6", "byrobot_petrone_v2_flight_controller_display_draw_line": "선 x1 %1, y1 %2, x2 %3, y2 %4 %5 %6 %7", "byrobot_petrone_v2_flight_controller_display_draw_point": "점 그리기 x %1, y %2 %3 %4", "byrobot_petrone_v2_flight_controller_display_draw_rect": "사각형 x %1, y %2, 너비 %3, 높이 %4 %5 %6 %7 %8", "byrobot_petrone_v2_flight_controller_display_draw_string": "문자열 x %1, y %2 %3 %4 입력 %5 %6", "byrobot_petrone_v2_flight_controller_display_draw_string_align": "문자열 정렬 x1 %1, x2 %2, y %3 %4 %5 %6 입력 %7 %8", "byrobot_petrone_v2_flight_controller_display_invert": "색반전 x %1, y %2, 너비 %3, 높이 %4 %5", "byrobot_petrone_v2_flight_controller_if_button_press": "조종기 %1 눌렀을 때", "byrobot_petrone_v2_flight_controller_if_joystick_direction": "조종기 %1 조이스틱 %2 움직였을 때", "byrobot_petrone_v2_flight_controller_light_color_rgb_input": "조종기 LED 색지정 R %1, G %2, B %3 %4 %5", "byrobot_petrone_v2_flight_controller_light_color_rgb_select": "조종기 LED의 RGB 조합 예시 %1 %2 %3", "byrobot_petrone_v2_flight_controller_light_manual_single": "조종기 LED %1 %2 %3", "byrobot_petrone_v2_flight_controller_light_manual_single_input": "조종기 LED %1 밝기 %2 %3", "byrobot_petrone_v2_flight_controller_light_manual_single_off": "조종기 LED 끄기 %1", "byrobot_petrone_v2_flight_controller_value_button": "%1", "byrobot_petrone_v2_flight_controller_value_joystick": "%1", "byrobot_petrone_v2_flight_controller_vibrator_delay": "진동 %1 초 켜기, %2 초 끄기를 %3 초 실행 %4", "byrobot_petrone_v2_flight_controller_vibrator_off": "진동 끄기 %1", "byrobot_petrone_v2_flight_controller_vibrator_on_delay": "진동 %1 초 켜기 %2", "byrobot_petrone_v2_flight_controller_vibrator_on_reserve": "진동 %1 초 예약 %2", "byrobot_petrone_v2_flight_controller_vibrator_reserve": "진동 %1 초 켜기, %2 초 끄기를 %3 초 예약 %4", "byrobot_petrone_v2_flight_drone_command_mode_vehicle_drone": "Vehicle mode %1 선택 %2", "byrobot_petrone_v2_flight_drone_control_coordinate": "(드론 좌표 기준) Headless mode %1 %2", "byrobot_petrone_v2_flight_drone_control_drone_landing": "드론 착륙 %1", "byrobot_petrone_v2_flight_drone_control_drone_reset_heading": "드론 방향 초기화 %1", "byrobot_petrone_v2_flight_drone_control_drone_stop": "드론 정지 %1", "byrobot_petrone_v2_flight_drone_control_drone_takeoff": "드론 이륙 %1", "byrobot_petrone_v2_flight_drone_control_quad": "드론 Roll %1%, Pitch %2%, Yaw %3%, Throttle %4% 정하기 %5", "byrobot_petrone_v2_flight_drone_control_quad_delay": "드론 Roll %1%, Pitch %2%, Yaw %3%, Throttle %4% %5초 실행 %6", "byrobot_petrone_v2_flight_drone_control_quad_one": "드론 %1 %2% 정하기 %3", "byrobot_petrone_v2_flight_drone_control_quad_one_delay": "드론 %1 %2% %3 초 실행 %4", "byrobot_petrone_v2_flight_drone_irmessage": "적외선으로 %1 값 보내기 %2", "byrobot_petrone_v2_flight_drone_light_color_rgb_input": "드론 %1 LED 색지정 R %2, G %3, B %4 %5 %6", "byrobot_petrone_v2_flight_drone_light_color_rgb_select": "드론 %1 LED의 RGB 조합 예시 %2 %3 %4", "byrobot_petrone_v2_flight_drone_light_manual_single": "드론 LED %1 %2 %3", "byrobot_petrone_v2_flight_drone_light_manual_single_input": "드론 LED %1 밝기 %2 %3", "byrobot_petrone_v2_flight_drone_light_manual_single_off": "드론 LED 끄기 %1", "byrobot_petrone_v2_flight_drone_motor_stop": "모터 정지 %1", "byrobot_petrone_v2_flight_drone_motorsingle": "%1번 모터를 %2(으)로 회전 %3", "byrobot_petrone_v2_flight_drone_motorsingle_input": "%1번 모터를 %2(으)로 회전 %3", "byrobot_petrone_v2_flight_drone_motorsingle_rotation": "%1번 모터를 %2으로 %3(으)로 회전 %4", "byrobot_petrone_v2_flight_drone_value_attitude": "%1", "byrobot_petrone_v2_flight_drone_value_etc": "%1", "byrobot_petrone_v2_flight_drone_value_imu": "%1", "byrobot_petrone_v2_flight_drone_value_sensor": "%1", "dplay_get_number_sensor_value": "아날로그 %1 번 센서값 ", "nemoino_get_number_sensor_value": "아날로그 %1 번 센서값 ", "sensorBoard_get_number_sensor_value": "아날로그 %1 번 센서값 ", "truetrue_get_accsensor": "가속도센서 %1 의 값", "truetrue_get_bottomcolorsensor": "바닥컬러센서 %1 의 값", "truetrue_get_frontcolorsensor": "전면컬러센서 %1 의 값", "truetrue_get_linesensor": "라인센서 %1 의 값", "truetrue_get_proxisensor": "근접센서 %1 의 값", "truetrue_set_colorled": "컬러LED Red %1 Green %2 Blue %3 로 설정 %4", "truetrue_set_dualmotor": "DC모터 좌 %1 우 %2 속도로 %3 초 구동 %4", "truetrue_set_led_colorsensor": "%1 조명용 LED %2 %3", "truetrue_set_led_linesensor": "라인센서 조명용 LED %1 %2", "truetrue_set_led_proxi": "%1 조명용 LED %2 %3", "truetrue_set_linetracer": "라인트레이싱 모드 %1 %2", "truetrue_set_singlemotor": "DC모터 %1 속도 %2 로 설정 %3", "CODEino_get_number_sensor_value": "아날로그 %1 번 센서값 ", "ardublock_get_number_sensor_value": "아날로그 %1 번 센서값 ", "arduino_get_digital_value": "디지털 %1 번 센서값 ", "dplay_get_digital_value": "디지털 %1 번 센서값 ", "nemoino_get_digital_value": "디지털 %1 번 센서값 ", "sensorBoard_get_digital_value": "디지털 %1 번 센서값 ", "CODEino_get_digital_value": "디지털 %1 핀의 값 ", "CODEino_set_digital_value": "디지털 %1 핀의 %2 %3", "CODEino_set_pwm_value": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "ardublock_get_digital_value": "디지털 %1 번 센서값 ", "arduino_toggle_led": "디지털 %1 번 핀 %2 %3", "dplay_toggle_led": "디지털 %1 번 핀 %2 %3", "nemoino_toggle_led": "디지털 %1 번 핀 %2 %3", "sensorBoard_toggle_led": "디지털 %1 번 핀 %2 %3", "CODEino_toggle_led": "디지털 %1 번 핀 %2 %3", "arduino_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "dplay_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "nemoino_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "sensorBoard_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "CODEino_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "ardublock_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "arduino_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "dplay_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "nemoino_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "sensorBoard_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "CODEino_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "CODEino_set_rgb_value": "컬러 LED의 %1 색상을 %2 (으)로 정하기 %3", "CODEino_set_rgb_add_value": "컬러 LED의 %1 색상에 %2 만큼 더하기 %3", "CODEino_set_rgb_off": "컬러 LED 끄기 %1", "CODEino_set__led_by_rgb": "컬러 LED 색상을 빨강 %1 초록 %2 파랑 %3 (으)로 정하기 %4", "CODEino_rgb_set_color": "컬러 LED의 색상을 %1 (으)로 정하기 %2", "CODEino_led_by_value": "컬러 LED 켜기 %1", "ardublock_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "joystick_get_number_sensor_value": "아날로그 %1 번 센서값 ", "joystick_get_digital_value": "디지털 %1 번 센서값 ", "joystick_toggle_led": "디지털 %1 번 핀 %2 %3", "joystick_toggle_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "joystick_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "sensorBoard_get_named_sensor_value": "%1 센서값", "sensorBoard_is_button_pressed": "%1 버튼을 눌렀는가?", "sensorBoard_led": "%1 LED %2 %3", "arduino_download_connector": "%1", "download_guide": "%1", "arduino_download_source": "%1", "arduino_connected": "%1", "arduino_connect": "%1", "arduino_reconnect": "%1", "CODEino_get_sensor_number": "%1 ", "CODEino_get_named_sensor_value": " %1 센서값 ", "CODEino_get_sound_status": "소리센서 %1 ", "CODEino_get_light_status": "빛센서 %1 ", "CODEino_is_button_pressed": " 보드의 %1 ", "CODEino_get_accelerometer_direction": " 3축 가속도센서 %1 ", "CODEino_get_accelerometer_value": " 3축 가속도센서 %1 축의 센서값 ", "CODEino_get_analog_value": "아날로그 %1 센서의 값", "iboard_button": "%1 버튼을 눌렀는가?", "iboard_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "iboard_get_analog_value": "아날로그 %1 번 센서값 ", "iboard_get_analog_value_map": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "iboard_get_digital": "디지털 %1 번 센서값 ", "iboard_led": "LED %1 번을 %2 %3", "iboard_motor": "모터를 %2 으로 동작하기 %3", "iboard_pwm_led": "LED %1 번의 밝기를 %2 (으)로 정하기 %3", "iboard_rgb_led": "RGB LED의 %1 LED %2 %3", "iboard_set_tone": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "iboard_toggle_led": "디지털 %1 번 핀 %2 %3", "bitbrick_sensor_value": "%1 값", "bitbrick_is_touch_pressed": "버튼 %1 이(가) 눌렸는가?", "bitbrick_turn_off_color_led": "컬러 LED 끄기 %1", "bitbrick_turn_on_color_led_by_rgb": "컬러 LED 켜기 R %1 G %2 B %3 %4", "bitbrick_turn_on_color_led_by_picker": "컬러 LED 색 %1 로 정하기 %2", "bitbrick_turn_on_color_led_by_value": "컬러 LED 켜기 색 %1 로 정하기 %2", "bitbrick_buzzer": "버저음 %1 내기 %2", "bitbrick_turn_off_all_motors": "모든 모터 끄기 %1", "bitbrick_dc_speed": "DC 모터 %1 속도 %2 %3", "bitbrick_dc_direction_speed": "DC 모터 %1 %2 방향 속력 %3 %4", "bitbrick_servomotor_angle": "서보 모터 %1 각도 %2 %3", "bitbrick_convert_scale": "변환 %1 값 %2 ~ %3 에서 %4 ~ %5", "start_drawing": "그리기 시작하기 %1", "stop_drawing": "그리기 멈추기 %1", "set_color": "붓의 색을 %1 (으)로 정하기 %2", "set_random_color": "붓의 색을 무작위로 정하기 %1", "change_thickness": "붓의 굵기를 %1 만큼 바꾸기 %2", "set_thickness": "붓의 굵기를 %1 (으)로 정하기 %2", "change_opacity": "붓의 불투명도를 %1 % 만큼 바꾸기 %2", "set_opacity": "붓의 불투명도를 %1 % 로 정하기 %2", "brush_erase_all": "모든 붓 지우기 %1", "brush_stamp": "도장찍기 %1", "change_brush_transparency": "붓의 투명도를 %1 % 만큼 바꾸기 %2", "set_brush_tranparency": "붓의 투명도를 %1 % 로 정하기 %2", "number": "%1", "angle": "%1", "get_x_coordinate": "%1", "get_y_coordinate": "%1", "get_angle": "%1", "get_rotation_direction": "%1 ", "distance_something": "%1 %2 %3", "coordinate_mouse": "%1 %2 %3", "coordinate_object": "%1 %2 %3 %4", "calc_basic": "%1 %2 %3", "calc_plus": "%1 %2 %3", "calc_minus": "%1 %2 %3", "calc_times": "%1 %2 %3", "calc_divide": "%1 %2 %3", "calc_mod": "%1 %2 %3 %4", "calc_share": "%1 %2 %3 %4", "calc_operation": "%1 %2 %3 %4", "calc_rand": "%1 %2 %3 %4 %5", "get_date": "%1 %2 %3", "get_sound_duration": "%1 %2 %3", "reset_project_timer": "%1", "set_visible_project_timer": "%1 %2 %3 %4", "timer_variable": "%1 %2", "get_project_timer_value": "%1 %2", "char_at": "%1 %2 %3 %4 %5", "length_of_string": "%1 %2 %3", "substring": "%1 %2 %3 %4 %5 %6 %7", "replace_string": "%1 %2 %3 %4 %5 %6 %7", "change_string_case": "%1 %2 %3 %4 %5", "index_of_string": "%1 %2 %3 %4 %5", "combine_something": "%1 %2 %3 %4 %5", "get_sound_volume": "%1 %2", "quotient_and_mod": "%1 %2 %3 %4 %5 %6", "choose_project_timer_action": "%1 %2 %3 %4", "wait_second": "%1 초 기다리기 %2", "repeat_basic": "%1 번 반복하기 %2", "hidden_loop": "%1 번 반복하기 %2", "repeat_inf": "계속 반복하기 %1", "stop_repeat": "반복 중단하기 %1", "wait_until_true": "%1 이(가) 될 때까지 기다리기 %2", "_if": "만일 %1 이라면 %2", "if_else": "만일 %1 이라면 %2 %3 아니면", "create_clone": "%1 의 복제본 만들기 %2", "delete_clone": "이 복제본 삭제하기 %1", "when_clone_start": "%1 복제본이 처음 생성되었을때", "stop_run": "프로그램 끝내기 %1", "repeat_while_true": "%1 %2 반복하기 %3", "stop_object": "%1 코드 멈추기 %2", "restart_project": "처음부터 다시 실행하기 %1", "remove_all_clones": "모든 복제본 삭제하기 %1", "functionAddButton": "%1", "function_field_label": "%1%2", "function_field_string": "%1%2", "function_field_boolean": "%1%2", "function_param_string": "문자/숫자값", "function_param_boolean": "판단값", "function_create": "함수 정의하기 %1 %2", "function_general": "함수 %1", "hamster_hand_found": "손 찾음?", "hamster_value": "%1", "hamster_move_forward_once": "말판 앞으로 한 칸 이동하기 %1", "hamster_turn_once": "말판 %1 으로 한 번 돌기 %2", "hamster_move_forward_for_secs": "앞으로 %1 초 이동하기 %2", "hamster_move_backward_for_secs": "뒤로 %1 초 이동하기 %2", "hamster_turn_for_secs": "%1 으로 %2 초 돌기 %3", "hamster_change_both_wheels_by": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 만큼 바꾸기 %3", "hamster_set_both_wheels_to": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 (으)로 정하기 %3", "hamster_change_wheel_by": "%1 바퀴 %2 만큼 바꾸기 %3", "hamster_set_wheel_to": "%1 바퀴 %2 (으)로 정하기 %3", "hamster_follow_line_using": "%1 선을 %2 바닥 센서로 따라가기 %3", "hamster_follow_line_until": "%1 선을 따라 %2 교차로까지 이동하기 %3", "hamster_set_following_speed_to": "선 따라가기 속도를 %1 (으)로 정하기 %2", "hamster_stop": "정지하기 %1", "hamster_set_led_to": "%1 LED를 %2 으로 정하기 %3", "hamster_clear_led": "%1 LED 끄기 %2", "hamster_beep": "삐 소리내기 %1", "hamster_change_buzzer_by": "버저 음을 %1 만큼 바꾸기 %2", "hamster_set_buzzer_to": "버저 음을 %1 (으)로 정하기 %2", "hamster_clear_buzzer": "버저 끄기 %1", "hamster_play_note_for": "%1 %2 음을 %3 박자 연주하기 %4", "hamster_rest_for": "%1 박자 쉬기 %2", "hamster_change_tempo_by": "연주 속도를 %1 만큼 바꾸기 %2", "hamster_set_tempo_to": "연주 속도를 %1 BPM으로 정하기 %2", "hamster_set_port_to": "포트 %1 를 %2 으로 정하기 %3", "hamster_change_output_by": "출력 %1 를 %2 만큼 바꾸기 %3", "hamster_set_output_to": "출력 %1 를 %2 (으)로 정하기 %3", "roboid_hamster_beep": "햄스터 %1: 삐 소리내기 %2", "roboid_hamster_change_both_wheels_by": "햄스터 %1: 왼쪽 바퀴 %2 오른쪽 바퀴 %3 만큼 바꾸기 %4", "roboid_hamster_change_buzzer_by": "햄스터 %1: 버저 음을 %2 만큼 바꾸기 %3", "roboid_hamster_change_output_by": "햄스터 %1: 출력 %2 를 %3 만큼 바꾸기 %4", "roboid_hamster_change_tempo_by": "햄스터 %1: 연주 속도를 %2 만큼 바꾸기 %3", "roboid_hamster_change_wheel_by": "햄스터 %1: %2 바퀴 %3 만큼 바꾸기 %4", "roboid_hamster_clear_buzzer": "햄스터 %1: 버저 끄기 %2", "roboid_hamster_clear_led": "햄스터 %1: %2 LED 끄기 %3", "roboid_hamster_follow_line_until": "햄스터 %1: %2 선을 따라 %3 교차로까지 이동하기 %4", "roboid_hamster_follow_line_using": "햄스터 %1: %2 선을 %3 바닥 센서로 따라가기 %4", "roboid_hamster_hand_found": "햄스터 %1: 손 찾음?", "roboid_hamster_move_backward_for_secs": "햄스터 %1: 뒤로 %2 초 이동하기 %3", "roboid_hamster_move_forward_for_secs": "햄스터 %1: 앞으로 %2 초 이동하기 %3", "roboid_hamster_move_forward_once": "햄스터 %1: 말판 앞으로 한 칸 이동하기 %2", "roboid_hamster_play_note_for": "햄스터 %1: %2 %3 음을 %4 박자 연주하기 %5", "roboid_hamster_rest_for": "햄스터 %1: %2 박자 쉬기 %3", "roboid_hamster_set_both_wheels_to": "햄스터 %1: 왼쪽 바퀴 %2 오른쪽 바퀴 %3 (으)로 정하기 %4", "roboid_hamster_set_buzzer_to": "햄스터 %1: 버저 음을 %2 (으)로 정하기 %3", "roboid_hamster_set_following_speed_to": "햄스터 %1: 선 따라가기 속도를 %2 (으)로 정하기 %3", "roboid_hamster_set_led_to": "햄스터 %1: %2 LED를 %3 으로 정하기 %4", "roboid_hamster_set_output_to": "햄스터 %1: 출력 %2 를 %3 (으)로 정하기 %4", "roboid_hamster_set_port_to": "햄스터 %1: 포트 %2 를 %3 으로 정하기 %4", "roboid_hamster_set_tempo_to": "햄스터 %1: 연주 속도를 %2 BPM으로 정하기 %3", "roboid_hamster_set_wheel_to": "햄스터 %1: %2 바퀴 %3 (으)로 정하기 %4", "roboid_hamster_stop": "햄스터 %1: 정지하기 %2", "roboid_hamster_turn_for_secs": "햄스터 %1: %2 으로 %3 초 돌기 %4", "roboid_hamster_turn_once": "햄스터 %1: 말판 %2 으로 한 번 돌기 %3", "roboid_hamster_value": "햄스터 %1: %2", "roboid_turtle_button_state": "거북이 %1: 버튼을 %2 ?", "roboid_turtle_change_buzzer_by": "거북이 %1: 버저 음을 %2 만큼 바꾸기 %3", "roboid_turtle_change_head_led_by_rgb": "거북이 %1: 머리 LED를 R: %2 G: %3 B: %4 만큼 바꾸기 %5", "roboid_turtle_change_tempo_by": "거북이 %1: 연주 속도를 %2 만큼 바꾸기 %3", "roboid_turtle_change_wheel_by": "거북이 %1: %2 바퀴 %3 만큼 바꾸기 %4", "roboid_turtle_change_wheels_by_left_right": "거북이 %1: 왼쪽 바퀴 %2 오른쪽 바퀴 %3 만큼 바꾸기 %4", "roboid_turtle_clear_head_led": "거북이 %1: 머리 LED 끄기 %2", "roboid_turtle_clear_sound": "거북이 %1: 소리 끄기 %2", "roboid_turtle_cross_intersection": "거북이 %1: 검은색 교차로 건너가기 %2", "roboid_turtle_follow_line": "거북이 %1: %2 선을 따라가기 %3", "roboid_turtle_follow_line_until": "거북이 %1: 검은색 선을 따라 %2 까지 이동하기 %3", "roboid_turtle_follow_line_until_black": "거북이 %1: %2 선을 따라 검은색까지 이동하기 %3", "roboid_turtle_is_color_pattern": "거북이 %1: 색깔 패턴이 %2 %3 인가?", "roboid_turtle_move_backward_unit": "거북이 %1: 뒤로 %2 %3 이동하기 %4", "roboid_turtle_move_forward_unit": "거북이 %1: 앞으로 %2 %3 이동하기 %4", "roboid_turtle_pivot_around_wheel_unit_in_direction": "거북이 %1: %2 바퀴 중심으로 %3 %4 %5 방향으로 돌기 %6", "roboid_turtle_play_note": "거북이 %1: %2 %3 음을 연주하기 %4", "roboid_turtle_play_note_for_beats": "거북이 %1: %2 %3 음을 %4 박자 연주하기 %5", "roboid_turtle_play_sound_times": "거북이 %1: %2 소리 %3 번 재생하기 %4", "roboid_turtle_play_sound_times_until_done": "거북이 %1: %2 소리 %3 번 재생하고 기다리기 %4", "roboid_turtle_rest_for_beats": "거북이 %1: %2 박자 쉬기 %3", "roboid_turtle_set_buzzer_to": "거북이 %1: 버저 음을 %2 (으)로 정하기 %3", "roboid_turtle_set_following_speed_to": "거북이 %1: 선 따라가기 속도를 %2 (으)로 정하기 %3", "roboid_turtle_set_head_led_to": "거북이 %1: 머리 LED를 %2 으로 정하기 %3", "roboid_turtle_set_head_led_to_rgb": "거북이 %1: 머리 LED를 R: %2 G: %3 B: %4 (으)로 정하기 %5", "roboid_turtle_set_tempo_to": "거북이 %1: 연주 속도를 %2 BPM으로 정하기 %3", "roboid_turtle_set_wheel_to": "거북이 %1: %2 바퀴 %3 (으)로 정하기 %4", "roboid_turtle_set_wheels_to_left_right": "거북이 %1: 왼쪽 바퀴 %2 오른쪽 바퀴 %3 (으)로 정하기 %4", "roboid_turtle_stop": "거북이 %1: 정지하기 %2", "roboid_turtle_touching_color": "거북이 %1: %2 에 닿았는가?", "roboid_turtle_turn_at_intersection": "거북이 %1: 검은색 교차로에서 %2 으로 돌기 %3", "roboid_turtle_turn_unit_in_place": "거북이 %1: %2 으로 %3 %4 제자리 돌기 %5", "roboid_turtle_turn_unit_with_radius_in_direction": "거북이 %1: %2 으로 %3 %4 반지름 %5 cm를 %6 방향으로 돌기 %7", "roboid_turtle_value": "거북이 %1: %2", "turtle_button_state": "버튼을 %1 ?", "turtle_change_buzzer_by": "버저 음을 %1 만큼 바꾸기 %2", "turtle_change_head_led_by_rgb": "머리 LED를 R: %1 G: %2 B: %3 만큼 바꾸기 %4", "turtle_change_tempo_by": "연주 속도를 %1 만큼 바꾸기 %2", "turtle_change_wheel_by": "%1 바퀴 %2 만큼 바꾸기 %3", "turtle_change_wheels_by_left_right": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 만큼 바꾸기 %3", "turtle_clear_head_led": "머리 LED 끄기 %1", "turtle_clear_sound": "소리 끄기 %1", "turtle_cross_intersection": "검은색 교차로 건너가기 %1", "turtle_follow_line": "%1 선을 따라가기 %2", "turtle_follow_line_until": "검은색 선을 따라 %1 까지 이동하기 %2", "turtle_follow_line_until_black": "%1 선을 따라 검은색까지 이동하기 %2", "turtle_is_color_pattern": "색깔 패턴이 %1 %2 인가?", "turtle_move_backward_unit": "뒤로 %1 %2 이동하기 %3", "turtle_move_forward_unit": "앞으로 %1 %2 이동하기 %3", "turtle_pivot_around_wheel_unit_in_direction": "%1 바퀴 중심으로 %2 %3 %4 방향으로 돌기 %5", "turtle_play_note": "%1 %2 음을 연주하기 %3", "turtle_play_note_for_beats": "%1 %2 음을 %3 박자 연주하기 %4", "turtle_play_sound_times": "%1 소리 %2 번 재생하기 %3", "turtle_play_sound_times_until_done": "%1 소리 %2 번 재생하고 기다리기 %3", "turtle_rest_for_beats": "%1 박자 쉬기 %2", "turtle_set_buzzer_to": "버저 음을 %1 (으)로 정하기 %2", "turtle_set_following_speed_to": "선 따라가기 속도를 %1 (으)로 정하기 %2", "turtle_set_head_led_to": "머리 LED를 %1 으로 정하기 %2", "turtle_set_head_led_to_rgb": "머리 LED를 R: %1 G: %2 B: %3 (으)로 정하기 %4", "turtle_set_tempo_to": "연주 속도를 %1 BPM으로 정하기 %2", "turtle_set_wheel_to": "%1 바퀴 %2 (으)로 정하기 %3", "turtle_set_wheels_to_left_right": "왼쪽 바퀴 %1 오른쪽 바퀴 %2 (으)로 정하기 %3", "turtle_stop": "정지하기 %1", "turtle_touching_color": "%1 에 닿았는가?", "turtle_turn_at_intersection": "검은색 교차로에서 %1 으로 돌기 %2", "turtle_turn_unit_in_place": "%1 으로 %2 %3 제자리 돌기 %4", "turtle_turn_unit_with_radius_in_direction": "%1 으로 %2 %3 반지름 %4 cm를 %5 방향으로 돌기 %6", "turtle_value": "%1", "is_clicked": "%1", "is_press_some_key": "%1 %2", "reach_something": "%1 %2 %3", "boolean_comparison": "%1 %2 %3", "boolean_equal": "%1 %2 %3", "boolean_bigger": "%1 %2 %3", "boolean_smaller": "%1 %2 %3", "boolean_and_or": "%1 %2 %3", "boolean_and": "%1 %2 %3", "boolean_or": "%1 %2 %3", "boolean_not": "%1 %2 %3", "true_or_false": "%1", "True": "%1 ", "False": "%1 ", "boolean_basic_operator": "%1 %2 %3", "show": "모양 보이기 %1", "hide": "모양 숨기기 %1", "dialog_time": "%1 을(를) %2 초 동안 %3 %4", "dialog": "%1 을(를) %2 %3", "remove_dialog": "말하기 지우기 %1", "change_to_nth_shape": "%1 모양으로 바꾸기 %2", "change_to_next_shape": "%1 모양으로 바꾸기 %2", "set_effect_volume": "%1 효과를 %2 만큼 주기 %3", "set_effect": "%1 효과를 %2 (으)로 정하기 %3", "erase_all_effects": "효과 모두 지우기 %1", "change_scale_percent": "크기를 %1 만큼 바꾸기 %2", "set_scale_percent": "크기를 %1 (으)로 정하기 %2", "change_scale_size": "크기를 %1 만큼 바꾸기 %2", "set_scale_size": "크기를 %1 (으)로 정하기 %2", "flip_y": "좌우 모양 뒤집기 %1", "flip_x": "상하 모양 뒤집기 %1", "set_object_order": "%1 번째로 올라오기 %2", "get_pictures": "%1 ", "change_to_some_shape": "%1 모양으로 바꾸기 %2", "add_effect_amount": "%1 효과를 %2 만큼 주기 %3", "change_effect_amount": "%1 효과를 %2 (으)로 정하기 %3", "set_effect_amount": "%1 효과를 %2 만큼 주기 %3", "set_entity_effect": "%1 효과를 %2 (으)로 정하기 %3", "change_object_index": "%1 보내기 %2", "move_direction": "이동 방향으로 %1 만큼 움직이기 %2", "move_x": "x 좌표를 %1 만큼 바꾸기 %2", "move_y": "y 좌표를 %1 만큼 바꾸기 %2", "locate_xy_time": "%1 초 동안 x: %2 y: %3 위치로 이동하기 %4", "rotate_by_angle": "오브젝트를 %1 만큼 회전하기 %2", "rotate_by_angle_dropdown": "%1 만큼 회전하기 %2", "see_angle": "이동 방향을 %1 (으)로 정하기 %2", "see_direction": "%1 쪽 보기 %2", "locate_xy": "x: %1 y: %2 위치로 이동하기 %3", "locate_x": "x: %1 위치로 이동하기 %2", "locate_y": "y: %1 위치로 이동하기 %2", "locate": "%1 위치로 이동하기 %2", "move_xy_time": "%1 초 동안 x: %2 y: %3 만큼 움직이기 %4", "rotate_by_angle_time": "오브젝트를 %1 초 동안 %2 만큼 회전하기 %3", "bounce_wall": "화면 끝에 닿으면 튕기기 %1", "flip_arrow_horizontal": "화살표 방향 좌우 뒤집기 %1", "flip_arrow_vertical": "화살표 방향 상하 뒤집기 %1", "see_angle_object": "%1 쪽 바라보기 %2", "see_angle_direction": "오브젝트를 %1 (으)로 정하기 %2", "rotate_direction": "이동 방향을 %1 만큼 회전하기 %2", "locate_object_time": "%1 초 동안 %2 위치로 이동하기 %3", "rotate_absolute": "방향을 %1 (으)로 정하기 %2", "rotate_relative": "방향을 %1 만큼 회전하기 %2", "direction_absolute": "이동 방향을 %1 (으)로 정하기 %2", "direction_relative": "이동 방향을 %1 만큼 회전하기 %2", "move_to_angle": "%1 방향으로 %2 만큼 움직이기 %3", "rotate_by_time": "%1 초 동안 방향을 %2 만큼 회전하기 %3", "direction_relative_duration": "%1 초 동안 이동 방향 %2 만큼 회전하기 %3", "neobot_sensor_value": "%1 값", "neobot_turn_left": "왼쪽모터를 %1 %2 회전 %3", "neobot_stop_left": "왼쪽모터 정지 %1", "neobot_turn_right": "오른쪽모터를 %1 %2 회전 %3", "neobot_stop_right": "오른쪽모터 정지 %1", "neobot_run_motor": "%1 모터를 %2 초간 %3 %4 %5", "neobot_servo_1": "SERVO1에 연결된 서보모터를 %1 속도로 %2 로 이동 %3", "neobot_servo_2": "SERVO2에 연결된 서보모터를 %1 속도로 %2 로 이동 %3", "neobot_play_note_for": "멜로디 %1 을(를) %2 옥타브로 %3 길이만큼 소리내기 %4", "neobot_set_sensor_value": "%1 번 포트의 값을 %2 %3", "robotis_openCM70_cm_custom_value": "직접입력 주소 ( %1 ) %2 값", "robotis_openCM70_sensor_value": "제어기 %1 값", "robotis_openCM70_aux_sensor_value": "%1 %2 값", "robotis_openCM70_cm_buzzer_index": "제어기 음계값 %1 을(를) %2 초 동안 연주 %3", "robotis_openCM70_cm_buzzer_melody": "제어기 멜로디 %1 번 연주 %2", "robotis_openCM70_cm_sound_detected_clear": "최종소리감지횟수 초기화 %1", "robotis_openCM70_cm_led": "제어기 %1 LED %2 %3", "robotis_openCM70_cm_motion": "모션 %1 번 실행 %2", "robotis_openCM70_aux_motor_speed": "%1 감속모터 속도를 %2 , 출력값을 %3 (으)로 정하기 %4", "robotis_openCM70_aux_servo_mode": "%1 서보모터 모드를 %2 (으)로 정하기 %3", "robotis_openCM70_aux_servo_speed": "%1 서보모터 속도를 %2 , 출력값을 %3 (으)로 정하기 %4", "robotis_openCM70_aux_servo_position": "%1 서보모터 위치를 %2 (으)로 정하기 %3", "robotis_openCM70_aux_led_module": "%1 LED 모듈을 %2 (으)로 정하기 %3", "robotis_openCM70_aux_custom": "%1 사용자 장치를 %2 (으)로 정하기 %3", "robotis_openCM70_cm_custom": "직접입력 주소 ( %1 ) (을)를 %2 (으)로 정하기 %3", "robotis_carCont_sensor_value": "%1 값", "robotis_carCont_cm_led": "4번 LED %1 , 1번 LED %2 %3", "robotis_carCont_cm_sound_detected_clear": "최종소리감지횟수 초기화 %1", "robotis_carCont_aux_motor_speed": "%1 감속모터 속도를 %2 , 출력값을 %3 (으)로 정하기 %4", "robotis_carCont_cm_calibration": "%1 적외선 센서 캘리브레이션 값을 %2 (으)로 정하기 %3", "roduino_get_analog_number": "%1 ", "roduino_get_port_number": "%1 ", "roduino_get_analog_value": "아날로그 %1 번 센서값 ", "roduino_get_digital_value": "디지털 %1 번 센서값 ", "roduino_set_digital": "디지털 %1 번 핀 %2 %3", "roduino_motor": "%1 %2 %3", "roduino_set_color_pin": "컬러센서 R : %1, G : %2, B : %3 %4", "roduino_get_color": "컬러센서 %1 감지", "roduino_on_block": " On ", "roduino_off_block": " Off ", "schoolkit_get_in_port_number": "%1 ", "schoolkit_get_out_port_number": "%1 ", "schoolkit_get_servo_port_number": "%1 ", "schoolkit_get_input_value": "디지털 %1 번 센서값 ", "schoolkit_set_output": "디지털 %1 번 핀 %2 %3", "schoolkit_motor": "%1 속도 %2(으)로 %3 %4", "schoolkit_set_servo_value": "서보모터 %1 번 핀 %2˚ %3", "schoolkit_on_block": " On ", "schoolkit_off_block": " Off ", "when_scene_start": "%1 장면이 시작되었을때", "start_scene": "%1 시작하기 %2", "start_neighbor_scene": "%1 장면 시작하기 %2", "sound_something": "소리 %1 재생하기 %2", "sound_something_second": "소리 %1 %2 초 재생하기 %3", "sound_something_wait": "소리 %1 재생하고 기다리기 %2", "sound_something_second_wait": "소리 %1 %2 초 재생하고 기다리기 %3", "sound_volume_change": "소리 크기를 %1 % 만큼 바꾸기 %2", "sound_volume_set": "소리 크기를 %1 % 로 정하기 %2", "sound_silent_all": "모든 소리 멈추기 %1", "get_sounds": "%1 ", "sound_something_with_block": "소리 %1 재생하기 %2", "sound_something_second_with_block": "소리 %1 %2 초 재생하기 %3", "sound_something_wait_with_block": "소리 %1 재생하고 기다리기 %2", "sound_something_second_wait_with_block": "소리 %1 %2 초 재생하고 기다리기 %3", "sound_from_to": "소리 %1 %2 초 부터 %3 초까지 재생하기 %4", "sound_from_to_and_wait": "소리 %1 %2 초 부터 %3 초까지 재생하고 기다리기 %4", "when_run_button_click": "%1 시작하기 버튼을 클릭했을 때", "press_some_key": "%1 %2 키를 눌렀을 때 %3", "when_some_key_pressed": "%1 %2 키를 눌렀을 때", "mouse_clicked": "%1 마우스를 클릭했을 때", "mouse_click_cancled": "%1 마우스 클릭을 해제했을 때", "when_object_click": "%1 오브젝트를 클릭했을 때", "when_object_click_canceled": "%1 오브젝트 클릭을 해제했을 때", "when_some_key_click": "%1 키를 눌렀을 때", "when_message_cast": "%1 %2 신호를 받았을 때", "message_cast": "%1 신호 보내기 %2", "message_cast_wait": "%1 신호 보내고 기다리기 %2", "text": "%1", "text_write": "%1 라고 글쓰기 %2", "text_append": "%1 라고 뒤에 이어쓰기 %2", "text_prepend": "%1 라고 앞에 추가하기 %2", "text_flush": "텍스트 모두 지우기 %1", "variableAddButton": "%1", "listAddButton": "%1", "change_variable": "%1 에 %2 만큼 더하기 %3", "set_variable": "%1 를 %2 로 정하기 %3", "show_variable": "변수 %1 보이기 %2", "hide_variable": "변수 %1 숨기기 %2", "get_variable": "%1 %2", "ask_and_wait": "%1 을(를) 묻고 대답 기다리기 %2", "get_canvas_input_value": "%1 ", "add_value_to_list": "%1 항목을 %2 에 추가하기 %3", "remove_value_from_list": "%1 번째 항목을 %2 에서 삭제하기 %3", "insert_value_to_list": "%1 을(를) %2 의 %3 번째에 넣기 %4", "change_value_list_index": "%1 %2 번째 항목을 %3 (으)로 바꾸기 %4", "value_of_index_from_list": "%1 %2 %3 %4 %5", "length_of_list": "%1 %2 %3", "show_list": "리스트 %1 보이기 %2", "hide_list": "리스트 %1 숨기기 %2", "options_for_list": "%1 ", "set_visible_answer": "대답 %1 %2", "is_included_in_list": "%1 %2 %3 %4 %5", "xbot_digitalInput": "%1", "xbot_analogValue": "%1", "xbot_digitalOutput": "디지털 %1 핀, 출력 값 %2 %3", "xbot_analogOutput": "아날로그 %1 %2 %3", "xbot_servo": "서보 모터 %1 , 각도 %2 %3", "xbot_oneWheel": "바퀴(DC) 모터 %1 , 속도 %2 %3", "xbot_twoWheel": "바퀴(DC) 모터 오른쪽(2) 속도: %1 왼쪽(1) 속도: %2 %3", "xbot_rgb": "RGB LED 켜기 R 값 %1 G 값 %2 B 값 %3 %4", "xbot_rgb_picker": "RGB LED 색 %1 로 정하기 %2", "xbot_buzzer": "%1 %2 음을 %3 초 연주하기 %4", "xbot_lcd": "LCD %1 번째 줄 , 출력 값 %2 %3", "run": "", "mutant": "test mutant block", "jr_start": "%1", "jr_repeat": "%1 %2 반복", "jr_item": "꽃 모으기 %1", "cparty_jr_item": "연필 줍기 %1", "jr_north": " 위쪽 %1", "jr_east": "오른쪽 %1", "jr_south": " 아래쪽 %1", "jr_west": " 왼쪽 %1", "jr_start_basic": "%1 %2", "jr_go_straight": "앞으로 가기%1", "jr_turn_left": "왼쪽으로 돌기%1", "jr_turn_right": "오른쪽으로 돌기%1", "jr_go_slow": "천천히 가기 %1", "jr_repeat_until_dest": "%1 만날 때까지 반복하기 %2", "jr_if_construction": "만약 %1 앞에 있다면 %2", "jr_if_speed": "만약 %1 앞에 있다면 %2", "maze_step_start": "%1 시작하기를 클릭했을 때", "maze_step_jump": "뛰어넘기%1", "maze_step_jump2": "뛰어넘기%1", "maze_step_jump_pinkbean": "뛰어넘기%1", "maze_step_for": "%1 번 반복하기%2", "test": "%1 this is test block %2", "maze_repeat_until_1": "%1 만날 때 까지 반복%2", "maze_repeat_until_2": "모든 %1 만날 때 까지 반복%2", "maze_step_if_1": "만약 앞에 %1 있다면%2", "maze_step_if_2": "만약 앞에 %1 있다면%2", "maze_call_function": "약속 불러오기%1", "maze_define_function": "약속하기%1", "maze_step_if_3": "만약 앞에 %1 있다면%2", "maze_step_if_4": "만약 앞에 %1 있다면%2", "maze_step_move_step": "앞으로 한 칸 이동%1", "maze_step_rotate_left": "왼쪽으로 회전%1", "maze_step_rotate_right": "오른쪽으로 회전%1", "maze_step_forward": "앞으로 가기%1", "maze_turn_right": "오른쪽 바라보기%1", "maze_turn_left": "왼쪽 바라보기%1", "maze_ladder_climb": "사다리 타기%1", "maze_attack_lupin": "%1공격하기%2", "maze_attack_both_side": "양옆 공격하기%1", "maze_attack_pepe": "%1 공격하기%2", "maze_attack_yeti": "%1 공격하기%2", "maze_attack_mushroom": "%1 공격하기%2", "maze_attack_peti": "%1 공격하기%2", "maze_eat_item": "음식 먹기%1", "maze_step_if_mushroom": "만약 한 칸 앞에 %1가 있다면 %2", "maze_step_if_yeti": "만약 앞에 %1가 있다면 %2 %3 아니면", "maze_step_if_left_monster": "만약 왼쪽 공격범위에 몬스터가 있다면 %1 %2 아니면", "maze_step_if_right_monster": "만약 오른쪽 공격범위에 몬스터가 있다면 %1 %2 아니면", "maze_step_if_lupin": "만약 두 칸 앞에 %1가 있다면 %2", "maze_step_if_else_road": "만약 한 칸 앞에 길이 있다면 %1 %2아니면", "maze_step_if_else_mushroom": "만약 한 칸 앞에 %1가 있다면 %2 %3아니면", "maze_step_if_else_lupin": "만약 두 칸 앞에 %1가 있다면 %2 %3아니면", "maze_step_if_else_ladder": "만약 한 칸 앞에 %1가 있다면 %2 %3아니면", "maze_rotate_left": "왼쪽으로 돌기%1", "maze_rotate_right": "오른쪽으로 돌기%1", "maze_moon_kick": "발차기하기%1", "maze_repeat_until_3": "%1에 도착할 때까지 반복하기%2", "maze_repeat_until_4": "%1에 도착할 때까지 반복하기%2", "maze_repeat_until_5": "%1에 도착할 때까지 반복하기%2", "maze_repeat_until_6": "%1에 도착할 때까지 반복하기%2", "maze_repeat_until_7": "%1에 도착할 때까지 반복하기%2", "maze_repeat_until_goal": "목적지에 도착할 때까지 반복하기%1", "maze_repeat_until_beat_monster": "모든 몬스터를 혼내줄 때까지 반복하기%1", "maze_radar_check": "%1에 %2이 있다", "maze_cony_flower_throw": "꽃 던지기%1", "maze_brown_punch": "주먹 날리기%1", "maze_iron_switch": "장애물 조종하기%1", "maze_james_heart": "하트 날리기%1", "maze_step_if_5": "만약 앞에 길이 없다면%2", "maze_step_if_6": "만약 앞에 %1이 없다면%2", "maze_step_if_7": "만약 앞에 %1이 있다면%2", "maze_step_if_8": "만약 %1이라면%2", "maze_step_if_else": "만약 %1이라면%2 %3 아니면", "test_wrapper": "%1 this is test block %2", "basic_button": "%1", "ai_move_right": "앞으로 가기 %1", "ai_move_up": "위쪽으로 가기 %1", "ai_move_down": "아래쪽으로 가기 %1", "ai_repeat_until_reach": "목적지에 도달 할 때까지 반복하기 %1", "ai_if_else_1": "만약 앞에 %1가 있다면 %2 %3 아니면", "ai_boolean_distance": "%1 레이더 %2 %3", "ai_distance_value": "%1 레이더", "ai_boolean_object": "%1 물체는 %2 인가?", "ai_use_item": "아이템 사용 %1", "ai_boolean_and": "%1 %2 %3", "ai_True": "%1", "ai_if_else": "만일 %1 이라면 %2 %3 아니면", "smartBoard_convert_scale": "%1 값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값", "smartBoard_get_named_sensor_value": "%1 센서값", "smartBoard_is_button_pressed": "%1 버튼을 눌렀는가?", "smartBoard_set_dc_motor_direction": "%1 DC 모터를 %2 방향으로 정하기 %3", "smartBoard_set_dc_motor_speed": "%1 DC모터를 %2 %3", "smartBoard_set_dc_motor_pwm": "%1 DC모터를 %2 속도로 돌리기 %3", "smartBoard_set_servo_speed": "%1 번 서보모터의 속도를 %2 %3", "smartBoard_set_servo_angle": "%1 번 서보모터를 %2 도 로 움직이기 %3", "smartBoard_set_number_eight_pin": "%1 포트를 %2 %3", "smartBoard_set_gs1_pwm": "GS1 포트의 PWM을 %1 로 정하기 %2", "robotori_digitalInput": "%1", "robotori_analogInput": "%1", "robotori_digitalOutput": "디지털 %1 핀, 출력 값 %2 %3", "robotori_analogOutput": "아날로그 %1 %2 %3", "robotori_servo": "서보모터 각도 %1 %2", "robotori_dc_direction": "DC모터 %1 회전 %2 %3", "dadublock_get_analog_value": "아날로그 %1 번 센서값", "dadublock_get_analog_value_map": "아날로그 %1번 센서값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값", "dadublock_get_ultrasonic_value": "울트라소닉 Trig %1번핀 Echo %2번핀 센서값", "dadublock_toggle_led": "디지털 %1 번 핀 %2 %3", "dadublock_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "dadublock_set_tone": "디지털 %1 번 핀을 %2 음으로 %3 옥타브로 %4 만큼 연주하기 %5", "dadublock_set_servo": "서보모터 %1 번 핀을 %2 의 각도로 정하기 %3", "coconut_stop_motor": "모터 정지 %1", "coconut_move_motor": "%1 움직이기 %2", "coconut_turn_motor": "%1 으로 돌기 %2", "coconut_move_for_secs": "%1 %2 초동안 움직이기 %3", "coconut_turn_for_secs": "%1 으로 %2 초동안 돌기 %3", "coconut_turn_to_led": "%1 으로 회전하는 동안 %2LED 켜기 %3", "coconut_move_outmotor": "외부모터 %1(으로) 움직이기 속도 %2 %3", "coconut_set_led_to": "%1 LED를 %2 으로 켜기 %3", "coconut_clear_led": "%1 LED 끄기 %2", "coconut_set_led_clear": "%1 LED %2 끄기 %3", "coconut_set_led_time": "%1 LED %2 으로 %3 초동안 켜기 %4", "coconut_beep": "버저 켜기 %1", "coconut_buzzer_time": "버저음을 %1 초 동안 소리내기 %2", "coconut_buzzer_set_hz": "버즈음 %1 Hz를 %2초 동안 소리내기 %3", "coconut_clear_buzzer": "버저 끄기 %1", "coconut_play_buzzer": "%1 %2 %3 음을 %4 박자로 연주하기 %5", "coconut_rest_buzzer": "%1 동안 쉬기 %2", "coconut_play_buzzer_led": "%1 %2 %3 음을 %4 박자로 연주하는 동안 %5 LED %6 켜기 %7", "coconut_play_midi": "%1 연주하기 %2", "coconut_floor_sensor": "%1 바닥센서", "coconut_floor_sensing": "%1 바닥센서 %2", "coconut_following_line": "선 따라가기 %1", "coconut_front_sensor": "%1 전방센서", "coconut_front_sensing": "%1 전방센서 %2", "coconut_obstruct_sensing": "장애물 감지", "coconut_avoid_mode": "어보이드 모드 %1", "coconut_dotmatrix_set": "도트매트릭스 %1 ( %2줄, %3칸 ) %4", "coconut_dotmatrix_on": "도트매트릭스 모두 켜기 %1", "coconut_dotmatrix_off": "도트매트릭스 모두 끄기 %1", "coconut_dotmatrix_num": "도트매트릭스 숫자 %1표시 %2", "coconut_dotmatrix_small_eng": "도트매트릭스 소문자 %1표시 %2", "coconut_dotmatrix_big_eng": "도트매트릭스 대문자 %1표시 %2", "coconut_dotmatrix_kor": "도트매트릭스 한글 %1표시 %2", "coconut_light_sensor": "밝기", "coconut_tem_sensor": "온도", "coconut_ac_sensor": "%1 가속도", "coconut_outled_sensor": "외부 LED 설정 %1 %2 초동안 켜기 %3", "coconut_outspk_sensor": "외부 스피커 설정 %1 %2Hz로 %3초 동안 소리내기 %4", "coconut_outspk_sensor_off": "외부 스피커 %1 끄기 %2", "coconut_outinfrared_sensor": "외부 적외선센서 %1", "coconut_outcds_sensor": "외부 빛센서(Cds) %1", "coconut_servomotor_angle": "서보모터 연결 %1 각도 %2 %3", "chocopi_control_button": "%1 컨트롤 %2번을 누름", "chocopi_control_event": "%1 %2 컨트롤 %3을 %4", "chocopi_control_joystick": "%1 컨트롤 %2의 값", "chocopi_dc_motor": "%1 DC모터 %2 %3% 세기 %4 방향 %5", "chocopi_led": "%1 LED %2 RGB(%3 %4 %5) %6", "chocopi_motion_photogate_event": "%1 %2 포토게이트 %3번을 %4", "chocopi_motion_photogate_status": "%1 포토게이트 %2번이 막힘", "chocopi_motion_photogate_time": "%1 포토게이트%2번을 %3", "chocopi_motion_value": "%1 모션 %2의 값", "chocopi_sensor": "%1 센서 %2", "chocopi_servo_motor": "%1 서보모터 %2번 %3도 %4", "chocopi_touch_event": "%1 %2 터치 %3번을 %4", "chocopi_touch_status": "%1 터치 %2번을 만짐", "chocopi_touch_value": "%1 터치 %2번의 값", "dadublock_car_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "dadublock_car_get_analog_value": "아날로그 %1 번 센서값", "dadublock_car_get_analog_value_map": "아날로그 %1번 센서값의 범위를 %2 ~ %3 에서 %4 ~ %5 (으)로 바꾼값 ", "dadublock_car_get_digital": "디지털 %1 번 센서값", "dadublock_car_get_irsensor": "적외선 %1 번 센서값", "dadublock_car_get_ultrasonic_value": "울트라소닉 Trig %1번핀 Echo %2번핀 센서값", "dadublock_car_motor": "모터 %1 번을 %2 (으)로 %3 %의 속도로 움직이기 %4", "dadublock_car_motor_stop": "모터 %1 번 멈추기 %2", "dadublock_car_set_servo": "서보모터 %1 번 핀을 %2 의 각도로 정하기 %3", "dadublock_car_set_tone": "디지털 %1 번 핀 을 %2 음으로 %3의 옥타브로 %4 만큼 연주하기 %5", "dadublock_car_toggle_led": "디지털 %1 번 핀 %2 %3", "dadublock_get_digital": "디지털 %1 번 센서값", "ev3_get_sensor_value": "%1 의 값", "ev3_touch_sensor": "%1 의 터치센서가 작동되었는가?", "ev3_color_sensor": "%1 의 %2 값", "ev3_motor_power": "%1 의 값을 %2 으로 출력 %3", "ev3_motor_power_on_time": "%1 의 값을 %2 초 동안 %3 으로 출력 %4", "ev3_motor_degrees": "%1 의 값을 %2 으로 %3 도 만큼 회전 %4", "rokoboard_get_sensor_value_by_name": "%1 의 센서값", "ardublock_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "ardublock_get_analog_value": "아날로그 %1 번 센서값", "ardublock_get_analog_value_map": "%1 의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼값", "ardublock_get_digital": "디지털 %1 번 센서값", "ardublock_get_left_cds_analog_value": "왼쪽 조도센서 %1 센서값", "ardublock_get_right_cds_analog_value": "오른쪽 조도센서 %1 센서값", "ardublock_get_sound_analog_value": "사운드(소리) 센서 %1 센서값", "ardublock_get_ultrasonic_value": "초음파센서 Trig %1 Echo %2 센서값", "ardublock_set_left_motor": "왼쪽모터를 %1 으로 %2 회전 속도로 정하기 %3", "ardublock_set_right_motor": "오른쪽모터를 %1 으로 %2 회전 속도로 정하기 %3", "ardublock_set_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "ardublock_set_tone": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "ardublock_toggle_led": "디지털 %1 번 핀 %2 %3", "ardublock_toggle_left_led": "왼쪽 라이트 %1 번 핀 %2 %3", "ardublock_toggle_right_led": "오른쪽 라이트 %1 번 핀 %2 %3", "mkboard_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "mkboard_get_analog_value": "아날로그 %1 번 센서값", "mkboard_get_analog_value_map": "%1 의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼값", "mkboard_get_digital": "디지털 %1 번 센서값", "mkboard_get_left_cds_analog_value": "왼쪽 조도센서 %1 센서값", "mkboard_get_right_cds_analog_value": "오른쪽 조도센서 %1 센서값", "mkboard_get_sound_analog_value": "사운드(소리) 센서 %1 센서값", "mkboard_get_ultrasonic_value": "초음파센서 Trig %1 Echo %2 센서값", "mkboard_set_left_dc_motor": "디지털 5번 DC모터를 %1 으로 %2 회전 속도로 정하기 %3", "mkboard_set_right_dc_motor": "디지털 6번 DC모터를 %1 으로 %2 회전 속도로 정하기 %3", "mkboard_set_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "mkboard_set_tone": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "mkboard_toggle_led": "디지털 %1 번 핀 %2 %3", "mkboard_toggle_left_led": "왼쪽 라이트 %1 번 핀 %2 %3", "mkboard_toggle_right_led": "오른쪽 라이트 %1 번 핀 %2 %3", "altino_analogValue": "알티노 %1 센서값", "altino_dot_display": "전광판에 %1 글자 표시하기 %2", "altino_dot_display_line": "1열 %1 2열 %2 3열 %3 4열 %4 5열 %5 6열 %6 7열 %7 8열 %8 출력하기 %9", "altino_light": "%1 등을 %2 %3", "altino_rear_wheel": "뒷바퀴 오른쪽 %1 왼쪽 %2 로 정하기 %3", "altino_sound": "%1 옥타브 %2 음을 연주하기 %3", "altino_steering": "방향을 %1 로 정하기 %2", "jdkit_altitude": "드론을 %1 높이만큼 날리기 %2", "jdkit_button": "%1번 버튼 값 읽어오기", "jdkit_connect": "드론 연결 상태 읽어오기", "jdkit_emergency": "드론을 즉시 멈추기 %1", "jdkit_gyro": "보드 %1 기울기 값 읽어오기", "jdkit_joystick": "조이스틱 %1 읽기", "jdkit_led": "%1 LED %2 %3", "jdkit_motor": "%1 모터를 %2 세기로 돌리기 %3", "jdkit_ready": "드론 비행 준비 상태 읽어오기", "jdkit_rollpitch": "드론을 %1 방향 %2 세기로 움직이기 %3", "jdkit_throttle": "드론 프로펠러를 %1 만큼 세기로 돌리기 %2", "jdkit_tune": "%1 음을 %2 초동안 소리내기 %3", "jdkit_ultrasonic": "거리(초음파)값 읽어오기", "jdkit_yaw": "드론을 %1 만큼 회전하기 %2", "memaker_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "memaker_get_analog_value": "아날로그 %1 번 센서값", "memaker_get_analog_value_map": "%1 의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼값", "memaker_get_digital": "디지털 %1 번 센서값", "memaker_get_ultrasonic_value": "초음파센서 Trig %1 Echo %2 센서값", "memaker_set_lcd": "1602 문자 LCD %1 행 , %2열에 %3 출력하기 %4", "memaker_set_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "memaker_toggle_led": "디지털 %1 번 핀 %2 %3", "memaker_lcd_command": "1602 문자 LCD %1 명령실행하기 %2", "edumaker_digital_pwm": "디지털 %1 번 핀을 %2 (으)로 정하기 %3", "edumaker_get_analog_value": "아날로그 %1 번 센서값", "edumaker_get_analog_value_map": "%1 의 범위를 %2 ~ %3 에서 %4 ~ %5 로 바꾼값", "edumaker_get_digital": "디지털 %1 번 센서값", "edumaker_get_ultrasonic_value": "울트라소닉 Trig %1 Echo %2 센서값", "edumaker_set_servo": "디지털 %1 번 핀의 서보모터를 %2 의 각도로 정하기 %3", "edumaker_set_tone": "디지털 %1 번 핀의 버저를 %2 %3 음으로 %4 초 연주하기 %5", "edumaker_toggle_led": "디지털 %1 번 핀 %2 %3" }; Lang.TextCoding = { "block_name": "블록명", "title_syntax": "문법오류 ", "title_converting": "변환오류", "message_syntax_default": "문법에 오류가 있습니다", "message_syntax_unexpected_token": "문법에 맞지 않는 토큰이 포함되어 있습니다", "message_syntax_reserved_token": "사용할 수 없는 변수명입니다.", "message_syntax_reserved_token_list": "사용할 수 없는 리스트명입니다.", "message_syntax_unexpected_character": "문법에 맞지 않는 문자가 포함되어 있습니다", "message_syntax_unexpected_indent": "문법에 맞지 않는 띄어쓰기가 포함되어 있습니다", "message_conv_default": "지원하지 않는 코드입니다", "message_conv_no_support": "변환될 수 없는 코드입니다", "message_conv_no_variable": "변수가 선언되지 않았습니다", "message_conv_no_list": "리스트가 선언되지 않았습니다", "message_conv_no_object": "객체는 지원되지 않습니다", "message_conv_no_function": "함수가 변환될 수 없습니다", "message_conv_no_entry_event_function": "엔트리 이벤트 함수는 다른 함수 안에 존재할 수 없습니다.", "message_conv_is_expect1": "올바르지 않은 문법입니다. ", "message_conv_is_expect2": " 가 올바르게 입력되었는지 확인해주세요.", "message_conv_instead": "올바르지 않은 문법입니다. %1 대신 %2 가 필요합니다.", "message_conv_is_wrong1": "올바르지 않은 문법입니다. ", "message_conv_is_wrong2": "(은/는) 올 수 없는 위치입니다.", "message_conv_or": " 나 ", "subject_syntax_default": "기타", "subject_syntax_token": "토큰", "subject_syntax_character": "문자", "subject_syntax_indent": "띄워쓰기", "subject_conv_default": "기타", "subject_conv_general": "일반", "subject_conv_variable": "변수", "subject_conv_list": "리스트", "subject_conv_object": "객체", "subject_conv_function": "함수", "alert_variable_empty_text": "등록된 변수 중에 공백(띄어쓰기)이 포함된 변수가 있으면 모드 변환을 할 수 없습니다.", "alert_list_empty_text": "등록된 리스트 중에 공백(띄어쓰기)이 포함된 리스트가 있으면 모드 변환을 할 수 없습니다.", "alert_function_name_empty_text": "등록된 함수 중에 함수 이름에 공백(띄어쓰기)이 포함된 함수가 있으면 모드 변환을 할 수 없습니다.", "alert_function_name_field_multi": "등록된 함수 중에 함수 이름에 [이름] 블록이 두번이상 포함되어 있으면 모드 변환을 할 수 없습니다.", "alert_function_name_disorder": "등록된 함수 중에[이름] 블록이 [문자/숫자값] 또는 [판단값] 블록보다 뒤에 쓰이면 모드 변환을 할 수 없습니다.", "alert_function_editor": "함수 생성 및 편집 중에는 모드 변환을 할 수 없습니다.", "alert_function_no_support": "텍스트모드에서는 함수 생성 및 편집을 할 수 없습니다.", "alert_list_no_support": "텍스트모드에서는 리스트 생성 및 편집을 할 수 없습니다.", "alert_variable_no_support": "텍스트모드에서는 변수 생성 및 편집을 할 수 없습니다.", "alert_signal_no_support": "텍스트모드에서는 신호 생성 및 편집을 할 수 없습니다.", "alert_legacy_no_support": "전환할 수 없는 블록이 존재하여 모드 변환을 할 수 없습니다.", "alert_variable_empty_text_add_change": "변수명 공백(띄어쓰기)이 포함될 수 없습니다.", "alert_list_empty_text_add_change": "리스트명에 공백(띄어쓰기)이 포함될 수 없습니다.", "alert_function_name_empty_text_add_change": "함수명에 공백(띄어쓰기)이 포함될 수 없습니다.", "alert_no_save_on_error": "문법 오류가 존재하여 작품을 저장할 수 없습니다.", "warn_unnecessary_arguments": "&(calleeName)(); 는 괄호 사이에 값이 입력될 필요가 없는 명령어 입니다. (line:&(lineNumber))", "python_code": " 오브젝트의 파이선 코드", "eof": "줄바꿈", "newline": "줄바꿈", "indent": "들여쓰기", "num": "숫자", "string": "문자열", "name": "변수명" }; Lang.PythonHelper = { "when_run_button_click_desc": "[시작하기]버튼을 클릭하면 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_run_button_click_exampleCode": "def when_start():\n Entry.print(\"안녕!\")", "when_run_button_click_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕!\"이라 말합니다.", "when_some_key_pressed_desc": "A키를 누르면 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_some_key_pressed_elements": "A-- 아래 선택지 중 하나<br>① 알파벳 : \"A\", \"B\" ~ \"Z\" 등(소문자 가능)<br>② 숫자 : 1, 2, 3, 4 ~ 9, 0<br>③ 특수키 : \"space\", \"enter\"<br>④ 방향키 : \"up\", \"down\", \"right\", \"left\"", "when_some_key_pressed_exampleCode": "def when_press_key(\"W\"):\n Entry.move_to_direction(10)\n\ndef when_press_key(1):\n Entry.add_size(10)", "when_some_key_pressed_exampleDesc": "W키를 누르면 오브젝트가 이동방향으로 10만큼 이동하고, 1키를 누르면 오브젝트의 크기가 10만큼 커집니다.", "mouse_clicked_desc": "마우스를 클릭했을 때 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "mouse_clicked_exampleCode": "def when_click_mouse_on():\n Entry.add_size(10)\n Entry.move_to_direction(10)", "mouse_clicked_exampleDesc": "마우스를 클릭하면 오브젝트의 크기가 10만큼 커지면서 이동방향으로 10만큼 이동합니다.", "mouse_click_cancled_desc": "마우스 클릭을 해제했을 때 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "mouse_click_cancled_exampleCode": "def when_click_mouse_off():\n Entry.move_to_direction(-10)\n\ndef when_click_mouse_on():\n Entry.move_to_direction(10)", "mouse_click_cancled_exampleDesc": "마우스를 클릭하면 오브젝트가 이동방향으로 10만큼 이동하고, 마우스 클릭을 해제하면 오브젝트가 이동방향으로 -10만큼 이동합니다.", "when_object_click_desc": "해당 오브젝트를 클릭했을 때 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_object_click_exampleCode": "def when_click_object_on():\n Entry.print_for_sec(\"회전!\", 0.5)\n Entry.add_rotation(90)", "when_object_click_exampleDesc": "오브젝트를 클릭하면 오브젝트가 \"회전!\"이라 말하고, 90도 만큼 회전합니다.", "when_object_click_canceled_desc": "해당 오브젝트 클릭을 해제했을 때 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_object_click_canceled_exampleCode": "def when_click_object_on():\n Entry.add_rotation(90)\n\ndef when_click_object_off():\n Entry.add_rotation(-90)", "when_object_click_canceled_exampleDesc": "오브젝트를 클릭하면 오브젝트가 90도 만큼 회전하고, 오브젝트 클릭을 해제하면 오브젝트가 -90도 만큼 회전합니다.", "when_message_cast_desc": "A 신호를 받으면 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.<br>만약 A 신호가 없으면 [속성] 탭에 A 신호가 자동 생성됩니다.", "when_message_cast_elements": "A-- \"신호 이름\"", "when_message_cast_exampleCode": "def when_click_mouse_on():\n Entry.send_signal(\"신호\")\n\ndef when_get_signal(\"신호\"):\n Entry.print_for_sec(\"안녕! 반가워\", 0.5)", "when_message_cast_exampleDesc": "마우스를 클릭하면 \"신호\"를 보내고, \"신호\"를 받았을때 \"안녕! 반가워\"라고 0.5초간 말합니다.", "message_cast_desc": "A에 입력된 신호를 보냅니다.<br>만약 A 신호가 없으면 [속성] 탭에 A 신호가 자동 생성됩니다.", "message_cast_elements": "A-- \"신호 이름\"", "message_cast_exampleCode": "#\"오브젝트1\"의 파이선 코드\ndef when_start():\n Entry.print_for_sec(\"안녕! 넌 몇살이니?\", 2)\n Entry.send_signal(\"신호\")\n\n#\"오브젝트2\"의 파이선 코드\ndef when_get_signal(\"신호\"):\n Entry.print_for_sec(\"안녕? 난 세 살이야.\", 2)", "message_cast_exampleDesc": "[시작하기]버튼을 클릭하면 \"오브젝트1\"이 \"안녕! 넌 몇살이니?\"라고 2초간 말하고 \"신호를 보냅니다., \"오브젝트2\"가 \"신호\"를 받았을때 \"안녕? 난 세 살이야.\"라고 2초간 말합니다.", "message_cast_wait_desc": "A에 입력된 신호를 보내고, 해당 신호를 받는 명령어들의 실행이 끝날 때까지 기다립니다.<br>만약 A 신호가 없으면 [속성] 탭에 A 신호가 자동 생성됩니다.", "message_cast_wait_elements": "A-- \"신호 이름\"", "message_cast_wait_exampleCode": "#\"오브젝트1\"의 파이선 코드\ndef when_start():\n Entry.print_for_sec(\"숨바꼭질하자!\", 2)\n Entry.send_signal_wait(\"신호\")\n Entry.hide()\n\n#\"오브젝트2\"의 파이선 코드\ndef when_get_signal(\"신호\"):\n Entry.print_for_sec(\"그래!\", 2)", "message_cast_wait_exampleDesc": "[시작하기]버튼을 클릭하면 \"오브젝트1\"이 \"숨바꼭질하자!\"라고 2초 동안 말하고 \"신호\"를 보낸 후 기다립니다. \"오브젝트2\"가 \"신호\"를 받으면 \"그래!\"를 2초 동안 말합니다. \"오브젝트1\"이 그 후에 모양을 숨깁니다.", "when_scene_start_desc": "장면이 시작되면 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_scene_start_exampleCode": "#\"장면 1\"의 파이선 코드\ndef when_start():\n Entry.print_for_sec(\"다른 곳으로 가볼까?\", 2)\n Entry.start_scene(\"장면 2\")\n\n#\"장면 2\"의 파이선 코드\ndef when_start_scene():\n Entry.print(\"여기가 어디지?\")", "when_scene_start_exampleDesc": "\"장면 1\"에서 [시작하기]버튼을 클릭하면 \"다른 곳으로 가볼까?\"라고 2초간 말하고, \"장면 2\"가 시작됩니다. \"장면 2\"가 시작되면 오브젝트가 \"여기가 어디지?\"라고 말합니다.", "start_scene_desc": "A 장면을 시작합니다.", "start_scene_elements": "A-- \"장면 이름\"", "start_scene_exampleCode": "#\"장면 1\"의 파이선 코드\ndef when_click_object_on():\n Entry.start_scene(\"장면 2\")", "start_scene_exampleDesc": "\"장면 1\"에서 해당 오브젝트를 클릭하면 \"장면 2\"가 시작됩니다.", "start_neighbor_scene_desc": "A에 입력한 다음 또는 이전 장면을 시작합니다.", "start_neighbor_scene_elements": "A-- 아래 선택지 중 하나<br>① 다음 장면: \"next\" 또는 \"다음\"<br>② 이전 장면: \"pre\" 또는 \"이전\"", "start_neighbor_scene_exampleCode": "#\"장면 1\"의 파이선 코드\ndef when_press_key(\"right\"):\n Entry.start_scene_of(\"next\")\n\n#\"장면 2\"의 파이선 코드\ndef when_press_key(\"left\"):\n Entry.start_scene_of(\"pre\")", "start_neighbor_scene_exampleDesc": "\"장면 1\"에서 오른쪽화살표키를 누르면 다음 장면이, \"장면 2\"에서 왼쪽화살표키를 누르면 이전 장면이 시작됩니다.", "wait_second_desc": "A초만큼 기다린 후 다음 블록을 실행합니다.", "wait_second_elements": "A-- 초에 해당하는 수 입력", "wait_second_exampleCode": "def when_start():\n Entry.add_effect(\"color\", 10)\n Entry.wait_for_sec(2)\n Entry.add_size(10)", "wait_second_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트에 색깔효과를 10만큼 주고, 2초동안 기다린 다음 크기를 10만큼 커지게 합니다.", "repeat_basic_desc": "아래 명령어들을 A번 반복하여 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "repeat_basic_elements": "A-- 반복할 횟수 입력", "repeat_basic_exampleCode": "def when_start():\n for i in range(10):\n Entry.move_to_direction(10)\n Entry.stamp()", "repeat_basic_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 이동방향으로 10만큼 이동하고, 도장찍는 행동을 10번 반복합니다.", "repeat_inf_desc": "A 판단이 True인 동안 아래 명령어들을 반복 실행합니다. A에 True를 입력하면 계속 반복됩니다. <br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "repeat_inf_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "repeat_inf_exampleCode": "def when_start():\n while True:\n Entry.move_to_direction(10)\n Entry.bounce_on_edge()", "repeat_inf_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 계속해서 이동방향으로 10만큼 이동하고, 벽에 닿으면 튕깁니다.", "repeat_while_true_desc": "A 판단이 True가 될 때까지 아래 명령어들을 반복 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "repeat_while_true_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "repeat_while_true_exampleCode": "def when_start():\n while not Entry.is_key_pressed(\"space\"):\n Entry.add_rotation(90)", "repeat_while_true_exampleDesc": "[시작하기]버튼을 클릭하면 스페이스키를 누를때까지 오브젝트가 90도 만큼 회전합니다.", "stop_repeat_desc": "이 명령어와 가장 가까운 반복 명령어의 반복을 중단합니다.", "stop_repeat_exampleCode": "def when_start():\n while True:\n Entry.move_to_direction(10)\n if Entry.is_key_pressed(\"enter\"):\n break", "stop_repeat_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 이동방향으로 10만큼 계속 이동합니다. 엔터키를 누르면 반복이 중단됩니다.", "_if_desc": "A 부분의 판단이 True이면 if A:아래 명령어들을 실행하고, False이면 실행하지 않습니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "_if_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "_if_exampleCode": "def when_click_mouse_on():\n if (Entry.value_of_mouse_pointer(\"x\") > 0):\n Entry.print_for_sec(\"오른쪽!\", 0.5)", "_if_exampleDesc": "마우스를 클릭했을 때 마우스 x좌표가 0보다 크면 오브젝트가 \"오른쪽!\"이라고 0.5초 동안 말합니다.", "if_else_desc": "A 부분의 판단이 True이면 if A: 아래 명령어들을 실행하고, False이면 else: 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "if_else_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "if_else_exampleCode": "def when_click_mouse_on():\n if Entry.is_touched(\"mouse_pointer\"):\n Entry.print(\"닿았다!\")\n else:\n Entry.print(\"안 닿았다!\")", "if_else_exampleDesc": "마우스를 클릭했을 때 마우스포인터가 오브젝트에 닿았으면 \"닿았다!\"를 그렇지 않으면 \"안 닿았다!\"를 말합니다.", "wait_until_true_desc": "A 부분의 판단이 True가 될 때까지 코드의 실행을 멈추고 기다립니다.", "wait_until_true_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "wait_until_true_exampleCode": "def when_start():\n Entry.print(\"엔터를 눌러봐!\")\n Entry.wait_until(Entry.is_key_pressed(\"enter\"))\n Entry.print(\"잘했어!\")", "wait_until_true_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"엔터를 눌러봐!\"라 말하고, 엔터키를 누를 때까지 기다립니다. 엔터키를 누르면 \"잘했어!\"라 말합니다.", "stop_object_desc": "A코드의 실행을 중지합니다.", "stop_object_elements": "A-- 아래 선택지 중 하나<br>① \"all\": 모든 오브젝트의 모든 코드<br>② \"self\" : 해당 오브젝트의 모든 코드<br>③ \"this\": 이 명령어가 포함된 코드<br>④ \"others\" : 해당 오브젝트의 코드 중 이 명령어가 포함된 코드를 제외한 모든 코드<br/>⑤ \"ohter_objects\" : 이 오브젝트를 제외한 다른 모든 오브젝트의 코드", "stop_object_exampleCode": "def when_start():\n while True:\n Entry.move_to(\"mouse_pointer\")\n\ndef when_press_key(\"space\"):\n Entry.stop_code(\"all\")\n", "stop_object_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 계속해서 마우스포인터 위치로 이동합니다. 스페이스키를 누르면 모든 코드의 실행이 중지됩니다.", "restart_project_desc": "작품을 처음부터 다시 실행합니다.", "restart_project_exampleCode": "def when_start():\n while True:\n Entry.add_size(10)\n\ndef when_press_key(\"enter\"):\n Entry.start_again()", "restart_project_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 오브젝트의 크기가 커집니다. 엔터키를 누르면 작품을 처음부터 다시 실행합니다.", "when_clone_start_desc": "해당 오브젝트의 복제본이 새로 생성되었을 때 아래 명령어들을 실행합니다.<br>아래 명령어는 [Tab]키를 통해 들여쓰기합니다.", "when_clone_start_exampleCode": "def when_start():\n for i in range(5):\n Entry.make_clone_of(\"self\")\n\ndef when_make_clone():\n Entry.set_x(random.randint(-200, 200))", "when_clone_start_exampleDesc": "[시작하기]버튼을 클릭하면 자신의 복제본 5개를 만듭니다. 복제본이 새로 생성되었을때 복제본의 x좌표를 -200에서 200사이의 무작위수로 정합니다.", "create_clone_desc": "A 오브젝트의 복제본을 생성합니다.", "create_clone_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"self\" 또는 \"자신\"", "create_clone_exampleCode": "def when_start():\n for i in range(5):\n Entry.make_clone_of(\"self\")\n\ndef when_make_clone():\n Entry.set_x(random.randint(-200, 200))", "create_clone_exampleDesc": "[시작하기]버튼을 클릭하면 자신의 복제본 5개를 만듭니다. 복제본이 새로 생성되었을때 복제본의 x좌표를 -200에서 200사이의 무작위수로 정합니다.", "delete_clone_desc": "Entry.make_clone_of(A) 명령에 의해 생성된 복제본을 삭제합니다.", "delete_clone_exampleCode": "def when_start():\n for i in range(5):\n Entry.make_clone_of(\"자신\")\n\ndef when_make_clone():\n Entry.set_x(random.randint(-200, 200))\n\ndef when_click_object_on():\n Entry.remove_this_clone()", "delete_clone_exampleDesc": "[시작하기]버튼을 클릭하면 자신의 복제본 5개를 만듭니다. 복제본이 새로 생성되었을때 복제본의 x좌표를 -200에서 200사이의 무작위수로 정합니다. 복제본을 클릭하면 클릭된 복제본을 삭제합니다.", "remove_all_clones_desc": "해당 오브젝트의 모든 복제본을 삭제합니다.", "remove_all_clones_exampleCode": "def when_start():\n for i in range(5):\n Entry.make_clone_of(\"자신\")\n\ndef when_make_clone():\n Entry.set_x(random.randint(-200, 200))\n\ndef when_press_key(\"space\"):\n Entry.remove_all_clone()", "remove_all_clones_exampleDesc": "[시작하기]버튼을 클릭하면 자신의 복제본 5개를 만듭니다. 복제본이 새로 생성되었을때 복제본의 x좌표를 -200에서 200사이의 무작위수로 정합니다. 스페이스 키를 누르면 모든 복제본을 삭제합니다.", "move_direction_desc": "A만큼 오브젝트의 이동방향 화살표가 가리키는 방향으로 움직입니다.", "move_direction_elements": "A-- 이동할 거리에 해당하는 수", "move_direction_exampleCode": "def when_start():\n Entry.move_to_direction(10)", "move_direction_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 이동방향으로 10만큼 이동합니다.", "bounce_wall_desc": "오브젝트가 화면 끝에 닿으면 튕겨져 나옵니다.", "bounce_wall_exampleCode": "def when_start():\n while True:\n Entry.move_to_direction(10)\n Entry.bounce_on_edge()", "bounce_wall_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 계속해서 이동방향으로 10만큼 이동하고, 벽에 닿으면 튕깁니다.", "move_x_desc": "오브젝트의 x좌표를 A만큼 바꿉니다.", "move_x_elements": "A-- x좌표의 변화 값<br>① 양수: 오브젝트가 오른쪽으로 이동합니다.<br>② 음수: 오브젝트가 왼쪽으로 이동합니다.", "move_x_exampleCode": "def when_start():\n Entry.add_x(10)\n Entry.wait_for_sec(2)\n Entry.add_x(-10)", "move_x_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 오른쪽으로 10만큼 이동하고 2초 동안 기다린 후 왼쪽으로 10만큼 이동합니다.", "move_y_desc": "오브젝트의 y좌표를 A만큼 바꿉니다.", "move_y_elements": "A-- y좌표의 변화 값<br>① 양수: 오브젝트가 위쪽으로 이동합니다.<br>② 음수: 오브젝트가 아래쪽으로 이동합니다.", "move_y_exampleCode": "def when_start():\n Entry.add_y(10)\n Entry.wait_for_sec(2)\n Entry.add_y(-10)", "move_y_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 위쪽으로 10만큼 이동하고 2초 동안 기다린 후 아래쪽으로 10만큼 이동합니다.", "move_xy_time_desc": "오브젝트가 x와 y좌표를 각각 A와 B만큼 C초에 걸쳐 서서히 바꿉니다.", "move_xy_time_elements": "A-- x좌표의 변화 값<br>① 양수: 오브젝트가 오른쪽으로 이동합니다.<br>② 음수: 오브젝트가 왼쪽으로 이동합니다.%nextB-- y좌표의 변화 값<br>① 양수: 오브젝트가 위쪽으로 이동합니다.<br>② 음수: 오브젝트가 아래쪽으로 이동합니다.%nextC-- 이동하는 시간(초)", "move_xy_time_exampleCode": "def when_start():\n Entry.add_xy_for_sec(100, 100, 2)\n Entry.add_xy_for_sec(-100, -100, 2)", "move_xy_time_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 오른쪽 위로 100만큼 2초 동안 이동한 후 왼쪽 아래로 100만큼 2초 동안 이동합니다.", "locate_x_desc": "오브젝트의 x좌표를 A로 정합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_x_elements": "A-- 이동할 x좌표", "locate_x_exampleCode": "def when_press_key(\"right\"):\n Entry.set_x(100)\n\ndef when_press_key(\"left\"):\n Entry.set_x(-100)\n", "locate_x_exampleDesc": "오른쪽화살표키를 누르면 오브젝트의 x좌표를 100으로 정하고, 왼쪽화살표키를 누르면 오브젝트의 x좌표를 -100으로 정합니다.", "locate_y_desc": "오브젝트의 y좌표를 A로 정합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_y_elements": "B-- 이동할 y좌표", "locate_y_exampleCode": "def when_press_key(\"up\"):\n Entry.set_y(100)\n\ndef when_press_key(\"down\"):\n Entry.set_y(-100)", "locate_y_exampleDesc": "위쪽화살표키를 누르면 오브젝트의 y좌표를 100으로 정하고, 아래쪽화살표키를 누르면 오브젝트의 y좌표를 -100으로 정합니다.", "locate_xy_desc": "오브젝트가 좌표(A, B)로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_xy_elements": "A-- 이동할 x좌표%nextB-- 이동할 y좌표", "locate_xy_exampleCode": "def when_click_mouse_on():\n Entry.set_xy(0, 0)\n\ndef when_press_key(\"right\"):\n Entry.add_x(10)\n\ndef when_press_key(\"up\"):\n Entry.add_y(10)", "locate_xy_exampleDesc": "오른쪽화살표키를 누르면 오브젝트의 x좌표를 10만큼 바꾸고, 위쪽화살표키를 누르면 오브젝트의 y좌표를 10만큼 바꿉니다. 마우스를 클릭하면 오브젝트의 x, y좌표를 0으로 정합니다.", "locate_xy_time_desc": "오브젝트가 좌표(A, B)로 C초에 걸쳐 서서히 이동합니다.(오브젝트의 중심점이 기준이 됩니다.)", "locate_xy_time_elements": "A-- 이동할 x좌표%nextB-- 이동할 y좌표%nextC-- 이동하는 시간", "locate_xy_time_exampleCode": "def when_click_mouse_on():\n Entry.set_xy_for_sec(0, 0, 2)\n\ndef when_press_key(\"right\"):\n Entry.add_x(10)\n\ndef when_press_key(\"up\"):\n Entry.add_y(10)", "locate_xy_time_exampleDesc": "오른쪽화살표키를 누르면 오브젝트의 x좌표를 10만큼 바꾸고, 위쪽화살표키를 누르면 오브젝트의 y좌표를 10만큼 바꿉니다. 마우스를 클릭하면 2초 동안 오브젝트를 x,y 좌표 0으로 이동시킵니다.", "locate_desc": "오브젝트가 A의 위치로 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"mouse_pointer\" 또는 \"마우스포인터\"", "locate_exampleCode": "def when_click_mouse_on():\n Entry.move_to(\"mouse_pointer\")\n\ndef when_press_key(\"space\"):\n Entry.move_to(\"오브젝트\")", "locate_exampleDesc": "마우스를 클릭하면 오브젝트가 마우스포인터 위치로 이동합니다.<br>스페이스키를 누르면 오브젝트가 \"오브젝트\" 위치로 이동합니다.", "locate_object_time_desc": "오브젝트가 A의 위치로 B초에 걸쳐 서서히 이동합니다. (오브젝트의 중심점이 기준이 됩니다.)", "locate_object_time_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"mouse_pointer\" 또는 \"마우스포인터\" %nextB-- 이동하는 시간(초)", "locate_object_time_exampleCode": "def when_click_mouse_on():\n Entry.move_to_for_sec(\"mouse_pointer\", 2)", "locate_object_time_exampleDesc": "마우스를 클릭하면 오브젝트가 2초 동안 서서히 마우스포인터 위치로 이동합니다.", "rotate_relative_desc": "오브젝트의 방향을 A도만큼 시계방향으로 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "rotate_relative_elements": "A-- 회전할 각도", "rotate_relative_exampleCode": "def when_click_object_on():\n Entry.add_rotation(90)\n\ndef when_click_object_off():\n Entry.add_rotation(-90)", "rotate_relative_exampleDesc": "오브젝트를 클릭하면 오브젝트가 90도 만큼 회전하고, 오브젝트 클릭을 해제하면 오브젝트가 -90도 만큼 회전합니다.", "direction_relative_desc": "오브젝트의 이동 방향을 A도만큼 회전합니다.", "direction_relative_elements": "A-- 회전할 각도", "direction_relative_exampleCode": "def when_start():\n Entry.move_to_direction(50)\n Entry.wait_for_sec(0.5)\n Entry.add_direction(90)\n Entry.wait_for_sec(0.5)\n Entry.move_to_direction(50)", "direction_relative_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 이동방향으로 50만큼 이동한 다음 0.5초간 기다립니다. 그 후 이동방향을 90도 만큼 회전하고 0.5초간 기다린 후 이동방향으로 50만큼 이동합니다.", "rotate_by_time_desc": "오브젝트의 방향을 시계방향으로 A도만큼 B초에 걸쳐 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "rotate_by_time_elements": "A-- 회전할 각도%nextB-- 회전할 시간(초)", "rotate_by_time_exampleCode": "def when_start():\n Entry.add_rotation_for_sec(90, 2)\n Entry.add_rotation_for_sec(-90, 2)", "rotate_by_time_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 2초 동안 90도 만큼 회전하고, 다시 2초 동안 -90도 만큼 회전합니다.", "direction_relative_duration_desc": "오브젝트의 이동방향을 시계방향으로 A도만큼 B초에 걸쳐 회전합니다. (오브젝트의 중심점을 기준으로 회전합니다.)", "direction_relative_duration_elements": "A-- 회전할 각도%nextB-- 회전할 시간(초)", "direction_relative_duration_exampleCode": "def when_start():\n Entry.add_direction_for_sec(90, 2)\n\ndef when_start():\n while True:\n Entry.move_to_direction(1)", "direction_relative_duration_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트의 이동방향을 2초 동안 90도만큼 회전시킵니다. 동시에 오브젝트는 이동방향으로 1만큼 계속 이동합니다.", "rotate_absolute_desc": "오브젝트의 방향을 A로 정합니다.", "rotate_absolute_elements": "A-- 설정할 방향", "rotate_absolute_exampleCode": "def when_press_key(\"right\"):\n Entry.set_rotation(90)\n\ndef when_press_key(\"left\"):\n Entry.set_rotation(270)", "rotate_absolute_exampleDesc": "오른쪽화살표키를 누르면 오브젝트의 방향을 90으로 정하고, 왼쪽화살표키를 누르면 오브젝트의 방향을 270으로 정합니다.", "direction_absolute_desc": "오브젝트의 이동방향을 A로 정합니다.", "direction_absolute_elements": "A-- 설정할 이동방향", "direction_absolute_exampleCode": "def when_press_key(\"right\"):\n Entry.set_direction(90)\n Entry.move_to_direction(10)\n\ndef when_press_key(\"left\"):\n Entry.set_direction(270)\n Entry.move_to_direction(10)", "direction_absolute_exampleDesc": "오른쪽화살표키를 누르면 오브젝트의 이동방향을 90으로 정한 후 해당 쪽으로 10만큼 이동하고, 왼쪽화살표키를 누르면 오브젝트의 이동방향을 270으로 정하고 해당쪽으로 10만큼 이동합니다.", "see_angle_object_desc": "오브젝트가 A쪽을 바라봅니다. (이동방향이 A를 향하도록 오브젝트의 방향을 회전해줍니다.)", "see_angle_object_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"mouse_pointer\" 또는 \"마우스포인터\"", "see_angle_object_exampleCode": "def when_click_mouse_on():\n Entry.look_at(\"mouse_pointer\")\n\ndef when_press_key(\"space\"):\n Entry.look_at(\"오브젝트\")", "see_angle_object_exampleDesc": "마우스를 클릭하면 오브젝트가 마우스포인터쪽을 바라보고, 스페이스키를 누르면 \"오브젝트\"쪽을 바라봅니다.", "move_to_angle_desc": "오브젝트가 A만큼 B방향으로 움직입니다.", "move_to_angle_elements": "A-- 이동할 거리에 해당하는 수%nextB-- 이동할 방향(12시 방향이 0도, 시계방향으로 증가)", "move_to_angle_exampleCode": "def when_press_key(\"up\"):\n Entry.move_to_degree(10, 0)\n\ndef when_press_key(\"down\"):\n Entry.move_to_degree(10, 180)", "move_to_angle_exampleDesc": "위쪽화살표키를 누르면 오브젝트가 0도방향으로 10만큼 이동하고, 아래쪽화살표키를 누르면 오브젝트가 180도방향으로 10만큼 이동합니다.", "show_desc": "오브젝트를 화면에 나타냅니다.", "show_exampleCode": "def when_start():\n Entry.wait_for_sec(1)\n Entry.hide()\n Entry.wait_for_sec(1)\n Entry.show()", "show_exampleDesc": "[시작하기]버튼을 클릭하면 1초 뒤에 오브젝트 모양이 숨겨지고, 다음 1초 뒤에 오브젝트 모양이 나타납니다.", "hide_desc": "오브젝트를 화면에서 보이지 않게 합니다.", "hide_exampleCode": "def when_start():\n Entry.wait_for_sec(1)\n Entry.hide()\n Entry.wait_for_sec(1)\n Entry.show()", "hide_exampleDesc": "[시작하기]버튼을 클릭하면 1초 뒤에 오브젝트 모양이 숨겨지고, 다음 1초 뒤에 오브젝트 모양이 나타납니다.", "dialog_time_desc": "오브젝트가 A를 B초 동안 말풍선으로 말한 후 다음 명령어가 실행됩니다. 콘솔창에서도 실행 결과를 볼 수 있습니다.", "dialog_time_elements": "A-- 말할 내용<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등%nextB-- 말하는 시간(초)", "dialog_time_exampleCode": "def when_start():\n Entry.print_for_sec(\"안녕! 나는\", 2)\n Entry.print_for_sec(16, 2)\n Entry.print_for_sec(\"살이야\", 2)", "dialog_time_exampleDesc": "[시작하기]버튼을 클릭하면 \"안녕! 나는\", 16, \"살이야\"를 각각 2초 동안 차례대로 말합니다.", "dialog_desc": "오브젝트가 A를 말풍선으로 말합니다. 콘솔창에서도 실행 결과를 볼 수 있습니다.", "dialog_elements": "A-- 말할 내용<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "dialog_exampleCode": "def when_start():\n Entry.print(\"키보드로 숫자 1,2 를 누르면 숫자를 말해볼게\")\n\ndef when_press_key(1):\n Entry.print(1)\n\ndef when_press_key(2):\n Entry.print(2)\n", "dialog_exampleDesc": "[시작하기]버튼을 클릭하면 \"키보드로 숫자 1,2 를 누르면 숫자를 말해볼게\"를 말하고, 키보드로 1, 2를 누르면 각각 1, 2라 말합니다.", "remove_dialog_desc": "오브젝트가 말하고 있는 말풍선을 지웁니다.", "remove_dialog_exampleCode": "def when_start():\n Entry.print(\"말풍선을 지우려면 엔터를 눌러!\")\n\ndef when_press_key(\"enter\"):\n Entry.clear_print()", "remove_dialog_exampleDesc": "[시작하기]버튼을 클릭하면 \"말풍선을 지우려면 엔터를 눌러!\"라 말하고, 엔터키를 누르면 말풍선이 사라집니다.", "change_to_some_shape_desc": "오브젝트를 A 모양으로 바꿉니다.", "change_to_some_shape_elements": "A-- 아래 선택지 중 하나<br>① 모양 이름 : [속성] 탭의 \"모양 이름\"을 적음<br>② 모양 번호 : [속성] 탭의 모양 번호를 적음", "change_to_some_shape_exampleCode": "def when_start():\n Entry.wait_for_sec(0.3)\n Entry.change_shape(\"오브젝트모양\")\n Entry.wait_for_sec(0.3)\n Entry.change_shape(\"오브젝트모양\")", "change_to_some_shape_exampleDesc": "[시작하기]버튼을 클릭하면 0.3초간 기다린 다음 \"오브젝트모양\"으로 모양을 바꾸고 0.3초간 기다린 다음 \"오브젝트모양\"모양으로 모양을 바꿉니다.", "change_to_next_shape_desc": "오브젝트의 모양을 다음 또는 이전 모양으로 바꿉니다.", "change_to_next_shape_elements": "A-- 아래 선택지 중 하나<br>① 다음 모양 : \"next\" 또는 \"다음\" <br>② 이전 모양 : \"pre\" 또는 \"이전\"", "change_to_next_shape_exampleCode": "def when_start():\n Entry.wait_for_sec(0.3)\n Entry.change_shape_to(\"next\")\n Entry.wait_for_sec(0.3)\n Entry.change_shape_to(\"pre\")", "change_to_next_shape_exampleDesc": "[시작하기]버튼을 클릭하면 0.3초간 기다린 다음 모양으로 오브젝트 모양을 바꾸고 0.3초간 기다린 다음 이전 모양으로 오브젝트 모양을 바꿉니다.", "add_effect_amount_desc": "오브젝트에 A 효과를 B만큼 줍니다.", "add_effect_amount_elements": "A -- 아래 선택지 중 하나<br>① “color” 또는 “색깔“ <br>② “brightness” 또는 “밝기” <br>③ “transparency” 또는 “투명도”%nextB-- 효과의 변화 정도", "add_effect_amount_exampleCode": "def when_click_mouse_on():\n Entry.add_effect(\"color\", 50)\n Entry.wait_for_sec(1)\n Entry.add_effect(\"brightness\", -50)\n Entry.wait_for_sec(1)\n Entry.add_effect(\"transparency\", 50)", "add_effect_amount_exampleDesc": "마우스를 클릭하면 오브젝트에 색깔 효과를 50만큼 주고 1초간 기다리고, 밝기 효과를 -50만큼 주고 1초간 기다립니다. 그 후 투명도 효과를 50만큼 줍니다.", "change_effect_amount_desc": "오브젝트의 A 효과를 B로 정합니다.", "change_effect_amount_elements": "A-- 아래 선택지 중 하나<br>① “color” 또는 “색깔“ <br>② “brightness” 또는 “밝기” <br>③ “transparency” 또는 “투명도”%nextB-- 효과의 값<br>① color: 0~100 범위의 수, 100을 주기로 반복됨<br>② brightness: -100~100 사이 범위의 수, -100이하는 -100 으로 100 이상은 100 으로 처리 됨<br>③ transparency: 0~100 사이 범위의 수, 0 이하는 0으로, 100이상은 100으로 처리 됨", "change_effect_amount_exampleCode": "def when_click_mouse_on():\n Entry.set_effect(\"color\", 50)\n Entry.set_effect(\"brightness\", 50)\n Entry.set_effect(\"transparency\", 50)\n\ndef when_click_mouse_off():\n Entry.set_effect(\"color\", 0)\n Entry.set_effect(\"brightness\", 0)\n Entry.set_effect(\"transparency\", 0)", "change_effect_amount_exampleDesc": "마우스를 클릭하면 오브젝트에 색깔, 밝기, 투명도 효과를 50으로 정하고, 마우스 클릭을 해제하면 각 효과를 0으로 정합니다.", "erase_all_effects_desc": "오브젝트에 적용된 효과를 모두 지웁니다.", "erase_all_effects_exampleCode": "def when_click_mouse_on():\n Entry.set_effect(\"color\", 50)\n Entry.set_effect(\"brightness\", 50)\n Entry.set_effect(\"transparency\", 50)\n\ndef when_click_mouse_off():\n Entry.clear_effect()\n", "erase_all_effects_exampleDesc": "마우스를 클릭하면 오브젝트에 색깔, 밝기, 투명도 효과를 50으로 정하고, 마우스 클릭을 해제하면 오브젝트에 적용된 모든 효과를 지웁니다.", "change_scale_size_desc": "오브젝트의 크기를 A만큼 바꿉니다.", "change_scale_size_elements": "A-- 크기 변화 값", "change_scale_size_exampleCode": "def when_press_key(\"up\"):\n Entry.add_size(10)\n\ndef when_press_key(\"down\"):\n Entry.add_size(-10)\n\ndef when_press_key(\"space\"):\n Entry.set_size(100)", "change_scale_size_exampleDesc": "위쪽화살표키를 누르면 오브젝트의 크기가 10만큼 커지고, 아래쪽화살표키를 누르면 오브젝트의 크기가 10만큼 작아집니다. 스페이스키를 누르면 오브젝트의 크기를 100으로 정합니다.", "set_scale_size_desc": "오브젝트의 크기를 A로 정합니다.", "set_scale_size_elements": "A-- 크기값", "set_scale_size_exampleCode": "def when_press_key(\"up\"):\n Entry.add_size(10)\n\ndef when_press_key(\"down\"):\n Entry.add_size(-10)\n\ndef when_press_key(\"space\"):\n Entry.set_size(100)", "set_scale_size_exampleDesc": "위쪽화살표키를 누르면 오브젝트의 크기가 10만큼 커지고, 아래쪽화살표키를 누르면 오브젝트의 크기가 10만큼 작아집니다. 스페이스키를 누르면 오브젝트의 크기를 100으로 정합니다.", "flip_x_desc": "오브젝트의 상하 모양을 뒤집습니다.", "flip_x_exampleCode": "def when_press_key(\"up\"):\n Entry.flip_horizontal()\n\ndef when_press_key(\"right\"):\n Entry.flip_vertical()", "flip_x_exampleDesc": "위쪽화살표키를 누르면 오브젝트의 상하 모양을 뒤집고, 오른쪽화살표키를 누르면 오브젝트의 좌우 모양을 뒤집습니다.", "flip_y_desc": "오브젝트의 좌우 모양을 뒤집습니다.", "flip_y_exampleCode": "def when_press_key(\"up\"):\n Entry.flip_horizontal()\n\ndef when_press_key(\"right\"):\n Entry.flip_vertical()", "flip_y_exampleDesc": "위쪽화살표키를 누르면 오브젝트의 상하 모양을 뒤집고, 오른쪽화살표키를 누르면 오브젝트의 좌우 모양을 뒤집습니다.", "change_object_index_desc": "오브젝트의 레이어를 A로 가져옵니다.", "change_object_index_elements": "A-- 아래 선택지 중 하나<br>① “front\" 또는 “맨 앞“ <br>② “forward” 또는 “앞” <br>③ “backward” 또는 “뒤”<br>④ “back” 또는 “맨 뒤”", "change_object_index_exampleCode": "def when_start():\n Entry.send_layer_to(\"front\")\n Entry.wait_for_sec(2)\n Entry.send_layer_to(\"backward\")", "change_object_index_exampleDesc": "오브젝트가 여러개가 겹쳐 있을 경우 [시작하기]버튼을 클릭하면 해당 오브젝트의 레이어를 가장 앞으로 가져와서 보여줍니다.", "brush_stamp_desc": "오브젝트의 모양을 도장처럼 실행화면 위에 찍습니다.", "brush_stamp_exampleCode": "def when_start():\n for i in range(10):\n Entry.move_to_direction(10)\n Entry.stamp()", "brush_stamp_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 이동방향으로 10만큼 이동하고, 도장찍는 행동을 10번 반복합니다.", "start_drawing_desc": "오브젝트가 이동하는 경로를 따라 선이 그려지기 시작합니다. (오브젝트의 중심점이 기준)", "start_drawing_exampleCode": "def when_start():\n Entry.start_drawing()\n for i in range(10):\n Entry.move_to_direction(10)", "start_drawing_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고, 오브젝트가 이동방향으로 10만큼 10번 이동할 때 오브젝트의 이동경로를 따라 선이 그려집니다.", "stop_drawing_desc": "오브젝트가 선을 그리는 것을 멈춥니다.", "stop_drawing_exampleCode": "def when_start():\n Entry.start_drawing()\n while True:\n Entry.move_to_direction(1)\n\ndef when_click_mouse_on():\n Entry.stop_drawing()", "stop_drawing_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고 계속해서 오브젝트가 이동방향으로 10만큼 이동합니다. 마우스를 클릭하면 그리는것을 멈춥니다.", "set_color_desc": "오브젝트가 그리는 선의 색을 A로 정합니다.", "set_color_elements": "A-- 아래 선택지 중 하나<br>① 색상 코드 : \"#FF0000\", \"#FFCC00\", \"#3333FF\", \"#000000\" 등<br>② 색깔명 : \"red\", \"orange\", \"yellow\", \"green\", \"blue\", \"navy\", \"purple\", \"black\", \"white\", \"brown\"", "set_color_exampleCode": "def when_start():\n Entry.start_drawing()\n Entry.set_brush_color_to(\"#000099\")\n while True:\n Entry.move_to_direction(1)", "set_color_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고, 선의 색을 \"#000099\"로 정합니다. 오브젝트는 계속해서 이동방향으로 1만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다.", "set_random_color_desc": "오브젝트가 그리는 선의 색을 무작위로 정합니다.", "set_random_color_exampleCode": "def when_start():\n Entry.start_drawing()\n while True:\n Entry.move_to_direction(1)\n Entry.set_brush_color_to_random()", "set_random_color_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작됩니다. 오브젝트는 계속해서 이동방향으로 1만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다. 선의 색깔은 계속해서 무작위로 정해집니다.", "change_thickness_desc": "오브젝트가 그리는 선의 굵기를 A만큼 바꿉니다.", "change_thickness_elements": "A-- 굵기 변화 값", "change_thickness_exampleCode": "def when_start():\n Entry.start_drawing()\n while True:\n Entry.add_brush_size(1)\n Entry.move_to_direction(10)", "change_thickness_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작됩니다. 오브젝트는 계속해서 이동방향으로 10만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다. 선의 굵기는 계속해서 1씩 커집니다.", "set_thickness_desc": "오브젝트가 그리는 선의 굵기를 A로 정합니다.", "set_thickness_elements": "A-- 굵기값(1이상의 수)", "set_thickness_exampleCode": "def when_start():\n Entry.start_drawing()\n Entry.set_brush_size(10)\n while True:\n Entry.move_to_direction(10)", "set_thickness_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고, 선의 굵기를 10으로 정합니다. 오브젝트는 계속해서 이동방향으로 10만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다.", "change_brush_transparency_desc": "오브젝트가 그리는 선의 투명도를 A만큼 바꿉니다.", "change_brush_transparency_elements": "A-- 투명도 변화 값", "change_brush_transparency_exampleCode": "def when_start():\n Entry.start_drawing()\n Entry.set_brush_size(10)\n while True:\n Entry.move_to_direction(10)\n Entry.add_brush_transparency(5)", "change_brush_transparency_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고, 선의 굵기를 10으로 정합니다. 오브젝트는 계속해서 이동방향으로 10만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다. 선의 투명도는 계속해서 5만큼 바꿉니다.", "set_brush_tranparency_desc": "오브젝트가 그리는 선의 투명도를 A로 정합니다.", "set_brush_tranparency_elements": "A-- 투명도값(0~100 의 범위)", "set_brush_tranparency_exampleCode": "def when_start():\n Entry.start_drawing()\n Entry.set_brush_size(10)\n Entry.set_brush_transparency(50)\n while True:\n Entry.move_to_direction(10)", "set_brush_tranparency_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작되고, 선의 굵기를 10으로, 선의 투명도를 50으로 정합니다. 오브젝트는 계속해서 이동방향으로 10만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다.", "brush_erase_all_desc": "오브젝트가 그린 선과 도장을 모두 지웁니다.", "brush_erase_all_exampleCode": "def when_start():\n Entry.start_drawing()\n while True:\n Entry.move_to_direction(10)\n\ndef when_click_mouse_on():\n Entry.clear_drawing()", "brush_erase_all_exampleDesc": "[시작하기]버튼을 클릭하면 그리기가 시작됩니다. 오브젝트는 계속해서 이동방향으로 10만큼 움직이고, 오브젝트의 이동경로를 따라 선이 그려집니다. 마우스를 클릭하면 오브젝트가 그린 선을 모두 지웁니다.", "text_write_desc": "글상자의 내용을 A로 고쳐씁니다.", "text_write_elements": "A-- 글상자의 내용<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "text_write_exampleCode": "def when_start():\n Entry.write_text(\"엔트리\")", "text_write_exampleDesc": "[시작하기]버튼을 클릭하면 글상자의 내용을 \"엔트리\"로 바꿉니다.", "text_append_desc": "글상자의 내용 뒤에 A를 추가합니다.", "text_append_elements": "A-- 글상자의 내용<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "text_append_exampleCode": "def when_start():\n Entry.write_text(\"안녕?\")\n Entry.wait_for_sec(1)\n Entry.append_text(\"엔트리!\")", "text_append_exampleDesc": "[시작하기]버튼을 클릭하면 글상자의 내용이 \"안녕?\"이 되었다가 1초 뒤에 \"엔트리!\"가 추가되어 \"안녕?엔트리!\"가 됩니다.", "text_prepend_desc": "글상자의 내용 앞에 A를 추가합니다.", "text_prepend_elements": "A-- 글상자의 내용<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "text_prepend_exampleCode": "def when_start():\n Entry.write_text(\"반가워!\")\n Entry.wait_for_sec(1)\n Entry.prepend_text(\"엔트리!\")", "text_prepend_exampleDesc": "[시작하기]버튼을 클릭하면 글상자의 내용이 \"반가워!\"가 되었다가 1초 뒤에 \"엔트리!\"가 앞에 추가되어 \"엔트리!반가워!\"가 됩니다.", "text_flush_desc": "글상자에 저장된 값을 모두 지웁니다.", "text_flush_exampleCode": "def when_start():\n Entry.write_text(\"엔트리\")\n Entry.wait_for_sec(1)\n Entry.clear_text()", "text_flush_exampleDesc": "[시작하기]버튼을 클릭하면 글상자의 내용이 \"엔트리\"가 되었다가 1초 뒤에 모든 내용이 사라집니다.", "sound_something_with_block_desc": "오브젝트가 A 소리를 재생합니다.", "sound_something_with_block_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_something_with_block_exampleCode": "def when_start():\n Entry.play_sound(\"소리\")\n Entry.add_size(50)", "sound_something_with_block_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 재생하면서 오브젝트의 크기가 50만큼 커집니다.", "sound_something_second_with_block_desc": "오브젝트가 A소리를 B초 만큼 재생합니다.", "sound_something_second_with_block_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_something_second_with_block_exampleCode": "def when_start():\n Entry.play_sound_for_sec(\"소리\", 1)\n Entry.add_size(50)", "sound_something_second_with_block_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 1초 동안 재생하면서, 오브젝트의 크기가 50만큼 커집니다.", "sound_from_to_desc": "오브젝트가 A소리를 B초부터 C초까지 재생합니다.", "sound_from_to_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_from_to_exampleCode": "def when_start():\n Entry.play_sound_from_to(\"소리\", 0.5, 1)\n Entry.add_size(50)", "sound_from_to_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 0.5초부터 1초 구간까지만 재생하면서, 오브젝트의 크기가 50만큼 커집니다.", "sound_something_wait_with_block_desc": "오브젝트가 A 소리를 재생하고, 재생이 끝나면 다음 명령을 실행합니다.", "sound_something_wait_with_block_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_something_wait_with_block_exampleCode": "def when_start():\n Entry.play_sound_and_wait(\"소리\")\n Entry.add_size(50)", "sound_something_wait_with_block_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 재생하고, 재생이 끝나면 오브젝트의 크기가 50만큼 커집니다.", "sound_something_second_wait_with_block_desc": "오브젝트가 A소리를 B초 만큼 재생하고, 재생이 끝나면 다음 명령을 실행합니다.", "sound_something_second_wait_with_block_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_something_second_wait_with_block_exampleCode": "def when_start():\n Entry.play_sound_for_sec_and_wait(\"소리\", 1)\n Entry.add_size(50)", "sound_something_second_wait_with_block_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 1초 동안 재생하고, 재생이 끝나면 오브젝트의 크기가 50만큼 커집니다.", "sound_from_to_and_wait_desc": "오브젝트가 A소리를 B초부터 C초까지 재생하고, 재생이 끝나면 다음 명령을 실행합니다.", "sound_from_to_and_wait_elements": "A-- 아래 선택지 중 하나<br>① 소리 이름 : [속성] 탭의 \"소리 이름\"을 적음<br>② 소리 번호: [속성] 탭의 소리 번호를 적음", "sound_from_to_and_wait_exampleCode": "def when_start():\n Entry.play_sound_from_to_and_wait(\"소리\", 0.5, 1)\n Entry.add_size(50)", "sound_from_to_and_wait_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 0.5초부터 1초 구간까지만 재생하고, 재생이 끝나면 오브젝트의 크기가 50만큼 커집니다.", "sound_volume_change_desc": "작품에서 재생되는 모든 소리의 크기를 A퍼센트만큼 바꿉니다.", "sound_volume_change_elements": "A-- 소리 크기 변화 값", "sound_volume_change_exampleCode": "def when_press_key(\"up\"):\n Entry.add_sound_volume(10)\n\ndef when_press_key(\"down\"):\n Entry.add_sound_volume(-10)\n\ndef when_start():\n while True:\n Entry.play_sound_and_wait(\"소리\")", "sound_volume_change_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 계속 재생합니다. 위쪽화살표키를 누르면 소리의 크기가 10\" 커지고, 아래쪽화살표키를 누르면 소리의 크기가 10\"작아집니다.", "sound_volume_set_desc": "작품에서 재생되는 모든 소리의 크기를 A퍼센트로 정합니다.", "sound_volume_set_elements": "A-- 소리 크기값", "sound_volume_set_exampleCode": "def when_press_key(\"up\"):\n Entry.add_sound_volume(10)\n\ndef when_press_key(\"down\"):\n Entry.add_sound_volume(-10)\n\ndef when_press_key(\"enter\"):\n Entry.set_sound_volume(100)\n\ndef when_start():\n while True:\n Entry.play_sound_and_wait(\"소리\")", "sound_volume_set_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 계속 재생합니다. 위쪽화살표키를 누르면 소리의 크기가 10\" 커지고, 아래쪽화살표키를 누르면 소리의 크기가 10\"작아집니다. 엔터키를 누르면 소리의 크기를 100\"로 정합니다.", "sound_silent_all_desc": "현재 재생 중인 모든 소리를 멈춥니다.", "sound_silent_all_exampleCode": "def when_start():\n while True:\n Entry.play_sound_and_wait(\"소리\")\n\ndef when_press_key(\"enter\"):\n Entry.stop_sound()", "sound_silent_all_exampleDesc": "[시작하기]버튼을 클릭하면 \"소리\"를 계속 재생합니다. 엔터키를 누르면 현재 재생 중인 소리를 멈춥니다.", "is_clicked_desc": "마우스를 클릭한 경우 True로 판단합니다.", "is_clicked_exampleCode": "def when_start():\n while True:\n if Entry.is_mouse_clicked():\n Entry.print_for_sec(\"반가워!\", 0.5)", "is_clicked_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 마우스를 클릭했는지 확인합니다. 만약 마우스를 클릭하면 오브젝트가 \"반가워!\"라고 0.5초간 말합니다.", "is_press_some_key_desc": "A 키가 눌려져 있는 경우 True로 판단합니다.", "is_press_some_key_elements": "A-- 아래 선택지 중 하나<br>① 알파벳 : \"A\", \"B\" ~ \"Z\" 등(소문자 가능)<br>② 숫자: 1, 2, 3, 4 ~ 9, 0<br>③ 특수키: \"space\", \"enter\"<br>④ 방향키 : \"up\", \"down\", \"right\", \"left\"", "is_press_some_key_exampleCode": "def when_start():\n while True:\n if Entry.is_key_pressed(\"space\"):\n Entry.move_to_direction(10)", "is_press_some_key_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 선택한 키를 눌렀는지 확인합니다. 만약 스페이스 키를 누르면 오브젝트가 이동방향으로 10만큼 이동합니다.", "reach_something_desc": "오브젝트가 A와 닿은 경우 True으로 판단합니다.", "reach_something_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"mouse_pointer\" 또는 \"마우스포인터\"<br>③ \"edge\", \"edge_up\", \"edge_down\", \"edge_right\", \"edge_left\"", "reach_something_exampleCode": "def when_start():\n while True:\n Entry.move_to_direction(10)\n if Entry.is_touched(\"edge\"):\n Entry.add_rotation(150)", "reach_something_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 오브젝트가 이동방향으로 10만큼 이동합니다. 만약 오브젝트가 벽에 닿으면 150만큼 회전하게 됩니다.", "boolean_basic_operator_desc": "A와 B를 비교하여 True 또는 False로 판단합니다.", "boolean_basic_operator_elements": "A, B-- 비교하고자 하는 숫자값<br>① == : A와 B의 값이 같으면 True, 아니면 False<br>② > : A의 값이 B의 값보다 크면 true, 아니면 False<br>③ < : A의 값이 B의 값보다 작으면 true, 아니면 False<br>④ >= : A의 값이 B의 값보다 크거나 같으면 true, 아니면 False<br>⑤ <= : A의 값이 B의 값보다 작거나 같으면 true, 아니면 False", "boolean_basic_operator_exampleCode": "def when_start():\n while True:\n Entry.add_x(10)\n if Entry.value_of_object(\"오브젝트\", \"x\") > 240:\n Entry.set_x(0)", "boolean_basic_operator_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 오브젝트 x좌표를 10만큼 바꿉니다. 만약 오브젝트 x좌표가 240보다 크면 오브젝트 x좌표를 0으로 정합니다.", "boolean_and_desc": "A와 B의 판단이 모두 True인 경우 True, 아닌 경우 False로 판단합니다.", "boolean_and_elements": "A, B-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "boolean_and_exampleCode": "def when_start():\n while True:\n if Entry.is_key_pressed(\"a\") and Entry.is_key_pressed(\"s\"):\n Entry.add_effect(\"color\", 10)", "boolean_and_exampleDesc": "[시작하기]버튼을 클릭하고 키보드의 \"a\" 와 \"s\"키를 동시에 눌렀을 때, 색깔 효과를 10만큼 줍니다.", "boolean_or_desc": "A와 B의 판단 중 하나라도 True인 경우 True, 아닌 경우 False로 판단합니다.", "boolean_or_elements": "A, B-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "boolean_or_exampleCode": "def when_start():\n while True:\n if Entry.is_key_pressed(\"a\") or Entry.is_key_pressed(\"s\"):\n Entry.add_effect(\"color\", 10)", "boolean_or_exampleDesc": "[시작하기]버튼을 클릭하면 키보드의 \"a\"나 \"s\"키 중 무엇이든 하나를 누르면 오브젝트에 색깔 효과를 10만큼 줍니다.", "boolean_not_desc": "A 판단이 True이면 False, False이면 True로 판단합니다.", "boolean_not_elements": "A-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① True, False<br>② 10 == 10 , 10 > 10 , 10 <= 10 등<br>③ Entry.is_mouse_clicked(), Entry.is_key_pressed(\"Q\") 등", "boolean_not_exampleCode": "def when_start():\n while True:\n if not Entry.is_mouse_clicked():\n Entry.add_size(1)", "boolean_not_exampleDesc": "[시작하기]버튼을 클릭하면 마우스를 클릭하지 않은 동안 크기가 1씩 커집니다.", "calc_basic_desc": "A와 B의 연산값입니다.", "calc_basic_elements": "A, B-- 연산하고자 하는 숫자값<br>① + : A와 B를 더한 값<br>② - : A와 B를 뺀 값<br>③ x : A와 B를 곱한 값<br>④ / : A와 B를 나눈 값", "calc_basic_exampleCode": "def when_start():\n Entry.print_for_sec(10 + 10, 2)\n Entry.print_for_sec(10 - 10, 2)\n Entry.print_for_sec(10 * 10, 2)\n Entry.print_for_sec(10 / 10, 2)", "calc_basic_exampleDesc": "[시작하기]버튼을 클릭하면 10과 10을 더한값, 뺀값, 곱한값, 나눈값을 각 2초간 말합니다.", "calc_rand_desc": "A와 B 사이에서 선택된 무작위 수의 값입니다. (두 수 모두 정수를 입력한 경우 정수로,두 수 중 하나라도 소수를 입력한 경우 소수로 무작위 수가 선택됩니다.)", "calc_rand_elements": "A, B-- 무작위 수를 추출할 범위<br>① random.randint(A, B) : A, B를 정수로 입력하면 정수 범위에서 무작위 수를 추출<br>② random.uniform(A, B) : A, B를 실수로 입력하면 실수 범위에서 무작위 수를 추출", "calc_rand_exampleCode": "def when_start():\n Entry.print_for_sec(random.randint(1, 10), 2)\n Entry.print_for_sec(random.uniform(0.1, 2), 2)", "calc_rand_exampleDesc": "[시작하기]버튼을 클릭하면 1부터 10사이의 정수중 무작위 수를 뽑아 2초간 말합니다. 그 후 0.1부터 2사이의 실수중 무작위 수를 뽑아 2초간 말합니다.", "coordinate_mouse_desc": "마우스 포인터의 A 좌표 값을 의미합니다.", "coordinate_mouse_elements": "A-- 아래 선택지 중 하나<br>① \"x\" 또는 \"X\"<br>② \"y\" 또는 \"Y\"", "coordinate_mouse_exampleCode": "def when_start():\n while True:\n Entry.print(Entry.value_of_mouse_pointer(\"x\"))", "coordinate_mouse_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 마우스 포인터의 x좌표를 계속해서 말합니다.", "coordinate_object_desc": "A에 대한 B정보값입니다.", "coordinate_object_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"self\" 또는 \"자신\"%nextB-- 아래 선택지 중 하나<br>① \"x\" 또는 \"X\"<br>② \"y\" 또는 \"Y\"<br>③ \"rotation\" 또는 \"방향\"<br>④ \"direction\" 또는 \"이동 방향\"<br>⑤ \"size\" 또는 \"크기\"<br>⑥ \"shape_number\" 또는 \"모양 번호\"<br>⑦ \"shape_name\" 또는 \"모양 이름\"", "coordinate_object_exampleCode": "def when_start():\n while True:\n Entry.add_x(1)\n Entry.print(Entry.value_of_object(\"오브젝트\", \"x\"))\n", "coordinate_object_exampleDesc": "[시작하기]버튼을 클릭하면 계속해서 오브젝트의 x좌표가 1씩 증가하며, \"오브젝트\"의 x좌표를 말합니다.", "get_sound_volume_desc": "현재 작품에 설정된 소리의 크기값입니다.", "get_sound_volume_exampleCode": "def when_start():\n while True:\n Entry.print(Entry.value_of_sound_volume())", "get_sound_volume_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 소리의 크기값을 계속해서 말합니다.", "quotient_and_mod_desc": "A와 B의 연산값입니다.", "quotient_and_mod_elements": "A, B-- 연산하고자 하는 숫자값<br>① // : A / B의 몫에 해당하는 값<br>② % : A / B의 나머지에 해당하는 값", "quotient_and_mod_exampleCode": "def when_start():\n Entry.print_for_sec(10 // 3, 2)\n Entry.print_for_sec(10 % 3, 2)", "quotient_and_mod_exampleDesc": "[시작하기]버튼을 클릭하면 10 / 3의 몫인 3을 2초 동안 말하고, 나머지인 1을 2초 동안 말합니다.", "calc_operation_desc": "A의 연산값입니다.", "calc_operation_elements": "A, B-- 연산하고자 하는 숫자값<br>① A ** 2 : A를 제곱한 값<br>② math.sqrt(A): A의 루트값<br>③ math.sin(A): A의 사인값<br>④ math.cos(A): A의 코사인 값<br>⑤ math.tan(A): A의 탄젠트값 <br>⑥ math.asin(A): A의 아크사인값<br>⑦ math.acos(A): A의 아크코사인값<br>⑧ math.atan(): A의 아크탄젠트값<br>⑨ math.log10(A): A의 로그값<br>⑩ math.log(A): A의 자연로그값<br>⑪ A - math.floor(A): A의 소수점 부분<br>⑫ math.floor(A): A의 소수점 버림값<br>⑬ math.ceil(A): A의 소수점 올림값<br>⑭ math.round(A): A의 반올림값<br>⑮ math.factorial(A): A의 팩토리얼 값<br>⑯ math.fabs(A): A의 절댓값", "calc_operation_exampleCode": "def when_start():\n Entry.print_for_sec(10 ** 2, 2)\n Entry.print_for_sec(math.sqrt(9), 2)\n Entry.print_for_sec(math.sin(90), 2)\n Entry.print_for_sec(math.fabs(-10), 2)", "calc_operation_exampleDesc": "[시작하기]버튼을 클릭하면 10의 제곱, 9의 루트값, 90의 사인값, -10의 절댓값을 각 2초 동안 말합니다.", "get_project_timer_value_desc": "이 명령이 실행되는 순간 초시계에 저장된 값입니다.", "get_project_timer_value_exampleCode": "def when_start():\n Entry.timer(\"start\")\n Entry.wait_for_sec(3)\n Entry.timer(\"stop\")\n Entry.timer_view(\"hide\")\n Entry.print(Entry.value_of_timer())", "get_project_timer_value_exampleDesc": "[시작하기]버튼을 클릭하면 초시계를 시작합니다. 3초 뒤에는 초시계를 정지하고 초시계창을 숨깁니다. 그 후 초시계값을 말합니다.", "choose_project_timer_action_desc": "초시계의 동작을 A로 정합니다.<br>(이 명령어를 사용하면 실행화면에 ‘초시계 창’이 생성됩니다.)", "choose_project_timer_action_elements": "A-- 아래 선택지 중 하나<br>① \"start\" : 초시계를 시작<br>② \"stop\" : 초시계를 정지<br>③ \"reset\" : 초시계를 초기화", "choose_project_timer_action_exampleCode": "def when_start():\n Entry.timer(\"start\")\n Entry.wait_for_sec(3)\n Entry.timer(\"stop\")\n Entry.timer_view(\"hide\")\n Entry.print(Entry.value_of_timer())", "choose_project_timer_action_exampleDesc": "[시작하기]버튼을 클릭하면 초시계를 시작합니다. 3초 뒤에는 초시계를 정지하고 초시계창을 숨깁니다. 그 후 초시계값을 말합니다.", "set_visible_project_timer_desc": "실행화면의 초시계 창을 A로 설정합니다.", "set_visible_project_timer_elements": "A-- 아래 선택지 중 하나<br>① \"hide\" : 초시계창을 숨김<br>② \"show\" : 초시계창을 보임", "set_visible_project_timer_exampleCode": "def when_start():\n Entry.timer(\"start\")\n Entry.wait_for_sec(3)\n Entry.timer(\"stop\")\n Entry.timer_view(\"hide\")\n Entry.print(Entry.value_of_timer())", "set_visible_project_timer_exampleDesc": "[시작하기]버튼을 클릭하면 초시계를 시작합니다. 3초 뒤에는 초시계를 정지하고 초시계창을 숨깁니다. 그 후 초시계값을 말합니다.", "get_date_desc": "현재 A에 대한 값입니다.", "get_date_elements": "A-- 아래 선택지 중 하나<br>① \"year\" : 현재 연도 값<br>② \"month\" : 현재 월 값<br>③ \"day\" : 현재 일 값<br>④ \"hour\" : 현재 시간 값<br>⑤ \"minute\" : 현재 분 값<br>⑥ \"second\" : 현재 초 값", "get_date_exampleCode": "def when_start():\n Entry.print(Entry.value_of_current_time(\"year\") + \"년\" + Entry.value_of_current_time(\"month\") + \"월\")", "get_date_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 현재년도와 월을 말합니다.", "distance_something_desc": "자신과 A까지의 거리 값입니다.", "distance_something_elements": "A-- 아래 선택지 중 하나<br>① \"오브젝트 이름\"<br>② \"mouse_pointer\" 또는 \"마우스포인터\"", "distance_something_exampleCode": "def when_start():\n while True:\n Entry.print(Entry.value_of_distance_to(\"mouse_pointer\"))", "distance_something_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 마우스포인터와의 거리를 계속해서 말합니다.", "get_sound_duration_desc": "소리 A의 길이(초)값입니다.", "get_sound_duration_elements": "A-- \"소리 이름\"", "get_sound_duration_exampleCode": "def when_start():\n Entry.print(Entry.value_of_sound_length_of(\"소리\"))", "get_sound_duration_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"소리\"의 길이를 말합니다.", "length_of_string_desc": "입력한 문자값의 공백을 포함한 글자 수입니다.", "length_of_string_elements": "A-- \"문자열\"", "length_of_string_exampleCode": "def when_start():\n Entry.print_for_sec(len(\"안녕\"), 2)\n Entry.print_for_sec(len(\"엔트리\"), 2)", "length_of_string_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕\"과 \"엔트리\"의 글자 수를 각각 2초 동안 말합니다.", "combine_something_desc": "A 문자열과 B 문자열을 결합한 값입니다. (A, B 중 하나가 숫자면 문자열로 바꾸어 처리되고, 둘 다 숫자면 덧셈 연산으로 처리됩니다.)", "combine_something_elements": "A, B-- \"문자열\"", "combine_something_exampleCode": "def when_start():\n Entry.print(\"안녕! \" + \"엔트리\")", "combine_something_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕!\"과 \"엔트리\"를 결합한 \"안녕! 엔트리\"를 말합니다.", "char_at_desc": "A 문자열의 B번째의 글자 값입니다. (첫 번째 글자의 위치는 0부터 시작합니다.)", "char_at_elements": "A-- \"문자열\"%nextB-- 찾고자 하는 문자열의 위치", "char_at_exampleCode": "def when_start():\n Entry.print(\"안녕 엔트리!\"[0])", "char_at_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕 엔트리!\"의 0번째 글자인 \"안\"을 말합니다.", "substring_desc": "A 문자열의 B위치부터 C-1위치까지의 값입니다. (첫 번째 글자의 위치는 0부터 시작합니다.)", "substring_elements": "A-- \"문자열\"%nextB-- 포함할 문자열의 시작 위치<br>첫 번째 글자는 0부터 시작%nextC-- 문자열을 포함하지 않는 위치", "substring_exampleCode": "def when_start():\n Entry.print(\"안녕 엔트리!\"[1:5])", "substring_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕 엔트리!\"의 1에서 4번째 글자인 \"녕 엔트\"를 말합니다.", "index_of_string_desc": "A문자열에서 B문자열이 처음으로 등장하는 위치의 값입니다. (첫 번째 글자의 위치는 0부터 시작합니다.)", "index_of_string_elements": "A, B-- \"문자열\"", "index_of_string_exampleCode": "def when_start():\n Entry.print(\"안녕 엔트리!\".find(\"엔트리\"))", "index_of_string_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕 엔트리!\"에서 \"엔트리\"가 처음으로 등장하는 위치인 3을 말합니다.", "replace_string_desc": "A 문자열에서 B문자열을 모두 찾아 C문자열로 바꾼 값입니다.<br>(영문 입력시 대소문자를 구분합니다.)", "replace_string_elements": "A, B, C-- \"문자열\"", "replace_string_exampleCode": "def when_start():\n Entry.print(\"안녕 엔트리!\".replace( \"안녕\", \"반가워\"))", "replace_string_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"안녕 엔트리!\"에서 \"안녕\"을 \"반가워\"로 바꾼 \"반가워 엔트리!\"를 말합니다.", "change_string_case_desc": "A의 모든 알파벳을 대문자 또는 소문자로 바꾼 문자값입니다.", "change_string_case_elements": "A-- \"문자열\"<br>① A.upper(): A의 모든 알파벳을 대문자로 바꾼 값<br>② A.lower() : A의 모든 알파벳을 소문자로 바꾼 값", "change_string_case_exampleCode": "def when_start():\n Entry.print_for_sec(\"Hello Entry!\".upper(), 2)\n Entry.print_for_sec(\"Hello Entry!\".lower(), 2)", "change_string_case_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"Hello Entry!\"를 모두 대문자로 바꾼 \"HELLO ENTRY!\"를 2초간 말한 다음 모두 소문자로 바꾼 \"hello entry!\"를 2초간 말합니다.", "ask_and_wait_desc": "오브젝트가 A 내용을 말풍선으로 묻고, 대답을 입력받습니다. 대답은 실행화면 또는 콘솔창에서 입력할 수 있으며 입력된 값은 'Entry.answer()'에 저장됩니다. <br>(이 명령어를 사용하면 실행화면에 ‘대답 창’이 생성됩니다.)", "ask_and_wait_elements": "A-- \"문자열\"", "ask_and_wait_exampleCode": "def when_start():\n Entry.input(\"이름을 입력해보세요.\")\n Entry.print(Entry.answer() + \" 반가워!\")", "ask_and_wait_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"이름을 입력해보세요.\"라고 말풍선으로 묻습니다. 이름을 입력하면 \"(입력한 이름) 반가워!\"라 말합니다.", "get_canvas_input_value_desc": "Entry.input(A) 명령에 의해 실행화면 또는 콘솔에서 입력받은 값입니다.", "get_canvas_input_value_exampleCode": "def when_start():\n Entry.input(\"이름을 입력해보세요.\")\n Entry.print(Entry.answer() + \" 반가워!\")", "get_canvas_input_value_exampleDesc": "[시작하기]버튼을 클릭하면 오브젝트가 \"이름을 입력해보세요.\"라고 말풍선으로 묻습니다. 이름을 입력하면 \"(입력한 이름) 반가워!\"라 말합니다.", "set_visible_answer_desc": "실행화면의 대답 창을 A로 설정합니다.", "set_visible_answer_elements": "A-- 아래 선택지 중 하나<br>① \"hide\" : 대답 창을 숨김<br>② \"show\" : 대답 창을 보임", "set_visible_answer_exampleCode": "def when_start():\n Entry.answer_view(\"hide\")\n Entry.input(\"나이를 입력하세요.\")\n Entry.print(Entry.answer())", "set_visible_answer_exampleDesc": "[시작하기]버튼을 클릭하면 대답창이 숨겨지고, 오브젝트가 \"나이를 입력하세요.\"라고 말풍선으로 묻습니다. 나이를 입력하면 오브젝트가 입력한 나이를 말합니다.", "get_variable_desc": "A 변수에 저장된 값입니다.", "get_variable_elements": "A-- 변수명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A", "get_variable_exampleCode": "age = 16\n\ndef when_start():\n Entry.print(age)", "get_variable_exampleDesc": "age라는 변수를 만들고 그 값을 16으로 정합니다. [시작하기]버튼을 클릭하면 오브젝트가 age 변수에 들어 가 있는 값인 \"16\"을 말합니다.", "change_variable_desc": "A 변수에 B만큼 더합니다.", "change_variable_elements": "A-- 변수명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 숫자값", "change_variable_exampleCode": "age = 16\n\ndef when_start():\n Entry.print_for_sec(age, 2)\n age += 2\n Entry.print_for_sec(age, 2)", "change_variable_exampleDesc": "age라는 변수를 만들고 그 값을 16으로 정합니다. [시작하기]버튼을 클릭하면 오브젝트가 age 변수에 들어 가 있는 값인 \"16\"을 2초 동안 말합니다. 그 후 age변수에 2를 더하고 더한값인 \"18\"을 2초 동안 말합니다.", "set_variable_desc": "A 변수의 값을 B로 정합니다. 만약 A 변수가 없으면 [속성] 탭에 A 변수가 자동 생성됩니다.", "set_variable_elements": "A-- 변수명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 변수에 넣을 값<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "set_variable_exampleCode": "age = 16\n\ndef when_start():\n Entry.print(age)", "set_variable_exampleDesc": "age라는 변수를 만들고 그 값을 16으로 정합니다. [시작하기]버튼을 클릭하면 오브젝트가 age 변수에 들어 가 있는 값인 \"16\"을 말합니다.", "show_variable_desc": "A 변수 창을 실행화면에 보이게 합니다.", "show_variable_elements": "A-- \"변수명\"<br>① 모든 오브젝트에서 사용: \"A\"<br>② 이 오브젝트에서 사용: \"self.A\"", "show_variable_exampleCode": "age = 16\n\ndef when_start():\n Entry.hide_variable(\"age\")\n Entry.wait_for_sec(2)\n age = 20\n Entry.show_variable(\"age\")", "show_variable_exampleDesc": "age라는 변수를 만들고 그 값을 16으로 정합니다. [시작하기]버튼을 클릭하면 age변수창을 실행화면에서 숨깁니다. 2초 후 변수값을 17로 바꾸고 age변수창을 실행화면에 보이게 합니다.", "hide_variable_desc": "A 변수 창을 실행화면에서 숨깁니다.", "hide_variable_elements": "A-- \"변수명\"<br>① 모든 오브젝트에서 사용: \"A\"<br>② 이 오브젝트에서 사용: \"self.A\"", "hide_variable_exampleCode": "age = 16\n\ndef when_start():\n Entry.hide_variable(\"age\")\n Entry.print_for_sec(age, 2)", "hide_variable_exampleDesc": "age라는 변수를 만들고 그 값을 16으로 정합니다. [시작하기]버튼을 클릭하면 age변수창을 실행화면에서 숨기고, 오브젝트가 age 변수에 들어 가 있는 값인 \"16\"을 2초 동안 말합니다.", "value_of_index_from_list_desc": "A 리스트에서 B위치의 항목 값을 의미합니다. <br>(첫 번째 항목의 위치는 0부터 시작합니다.)", "value_of_index_from_list_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 리스트 항목의 위치", "value_of_index_from_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n Entry.print(basket[1])\n", "value_of_index_from_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 오브젝트가 basket 리스트의 1번째 항목인 orange를 말합니다.", "add_value_to_list_desc": "A 리스트의 마지막 항목으로 B값이 추가됩니다.", "add_value_to_list_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 리스트에 넣을 항목 값<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "add_value_to_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n basket.append(\"juice\")\n Entry.print(basket[4])", "add_value_to_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 \"juice\"를 basket의 마지막 항목으로 추가합니다. 오브젝트는 basket의 4번째 항목인 \"juice\"를 말합니다.", "remove_value_from_list_desc": "A 리스트의 B위치에 있는 항목을 삭제합니다.<br>(첫 번째 항목의 위치는 0부터 시작합니다.)", "remove_value_from_list_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 리스트 항목의 위치값", "remove_value_from_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\ndef when_start():\n basket.pop(0)\n Entry.print(basket[0])", "remove_value_from_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket의 0번째 항목인 apple을 삭제합니다. 오브젝트는 새롭게 basket의 0번째 항목이 된 \"orange\"를 말합니다.", "insert_value_to_list_desc": "A 리스트의 B위치에 C항목을 끼워 넣습니다. <br>(첫 번째 항목의 위치는 0부터 시작합니다. B위치보다 뒤에 있는 항목들은 순서가 하나씩 밀려납니다.)", "insert_value_to_list_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 리스트 항목의 위치%nextC-- 리스트에 넣을 항목 값<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "insert_value_to_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n basket.insert(1, \"juice\")\n Entry.print(basket[2])", "insert_value_to_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket의 1번째 위치에 항목 \"juice\"를 끼워 넣습니다. 오브젝트는 새롭게 basket의 2번째 항목이 된 \"orange\"를 말합니다.", "change_value_list_index_desc": "A 리스트에서 B위치에 있는 항목의 값을 C 값으로 바꿉니다.<br>(첫 번째 항목의 위치는 0부터 시작합니다.)", "change_value_list_index_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A%nextB-- 리스트 항목의 위치%nextC-- 리스트에 넣을 항목 값<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등", "change_value_list_index_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n basket[0] = \"juice\"\n Entry.print(basket[0])", "change_value_list_index_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket의 0번째 위치의 항목 \"apple\"을 \"juice\"로 바꿉니다. 오브젝트는 바뀐 basket의 0번째 항목 \"juice\"를 말합니다.", "length_of_list_desc": "A 리스트가 보유한 항목 개수 값입니다.", "length_of_list_elements": "A-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A", "length_of_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n Entry.print(len(basket))", "length_of_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 오브젝트는 basket의 항목 개수인 4를 말합니다.", "is_included_in_list_desc": "A값을 가진 항목이 B리스트에 포함되어 있는지 확인합니다.", "is_included_in_list_elements": "A-- 리스트의 항목 값<br>① 문자 : \"안녕!\", \"엔트리\" 등 <br>② 숫자 : 0, 10, 35 등%nextB-- 리스트명<br>① 모든 오브젝트에서 사용: A<br>② 이 오브젝트에서 사용: self.A", "is_included_in_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n if \"apple\" in basket:\n Entry.print(\"사과가 있어!\")", "is_included_in_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket 리스트에 \"apple\"항목이 있는지 확인합니다. \"apple\"항목이 있기 때문에 오브젝트는 \"사과가 있어!\"라 말합니다.", "show_list_desc": "선택한 리스트 창을 실행화면에 보이게 합니다.", "show_list_elements": "A-- \"리스트명\"<br>① 모든 오브젝트에서 사용: \"A\"<br>② 이 오브젝트에서 사용: \"self.A\"", "show_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n Entry.hide_list(\"basket\")\n Entry.wait_for_sec(2)\n Entry.show_list(\"basket\")", "show_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket 리스트를 2초간 숨긴 다음 보여줍니다.", "hide_list_desc": "선택한 리스트 창을 실행화면에서 숨깁니다.", "hide_list_elements": "A-- \"리스트명\"<br>① 모든 오브젝트에서 사용: \"A\"<br>② 이 오브젝트에서 사용: \"self.A\"", "hide_list_exampleCode": "basket = [\"apple\", \"orange\", \"pear\", \"grape\"]\n\ndef when_start():\n Entry.hide_list(\"basket\")\n Entry.wait_for_sec(2)\n Entry.show_list(\"basket\")", "hide_list_exampleDesc": "basket이라는 리스트를 만들고 4개의 항목을 넣습니다. [시작하기]버튼을 클릭하면 basket 리스트를 2초간 숨긴 다음 보여줍니다.", "boolean_and_or_desc": "A와 B의 판단값을 확인하여 True 또는 False로 판단합니다.", "boolean_and_or_elements": "A, B-- True 또는 False로 판단할 수 있는 명령어 입력(판단 카테고리의 명령어)<br>① and : A와 B의 판단이 모두 True인 경우 True, 아닌 경우 False<br>② or : A와 B의 판단 중 하나라도 True인 경우 True, 아닌 경우 False", "boolean_and_or_exampleCode": "def when_start():\n while True:\n if Entry.is_key_pressed(\"a\") and Entry.is_key_pressed(\"s\"):\n Entry.add_effect(\"color\", 10)", "boolean_and_or_exampleDesc": "[시작하기]버튼을 클릭하고 키보드의 \"a\" 와 \"s\"키를 동시에 눌렀을 때, 색깔 효과를 10만큼 줍니다." }; if (typeof exports == "object") exports.Lang = Lang;<|fim▁end|>
"analyze_dataRepresentation": "데이터 표현", "analyze_abstraction": "추상화",
<|file_name|>api.ts<|end_file_name|><|fim▁begin|>// ==LICENSE-BEGIN== // Copyright 2017 European Digital Reading Lab. All rights reserved. // Licensed to the Readium Foundation under one or more contributor license agreements. // Use of this source code is governed by a BSD-style license // that can be found in the LICENSE file exposed on Github (readium) in the project repository. // ==LICENSE-END== import { TApiMethod, TApiMethodName } from "readium-desktop/common/api/api.type"; import { TMethodApi } from "readium-desktop/common/api/methodApi.type"; import { TModuleApi } from "readium-desktop/common/api/moduleApi.type";<|fim▁hole|>import { put } from "redux-saga/effects"; /** * * api function to dispatch an api request in redux-saga. * should be call with yield* to delegate to another generator * * @param apiPath name of the api * @param requestId id string channel * @param requestData typed api parameter */ export function apiSaga<T extends TApiMethodName>( apiPath: T, requestId: string, ...requestData: Parameters<TApiMethod[T]> ) { const splitPath = apiPath.split("/"); const moduleId = splitPath[0] as TModuleApi; const methodId = splitPath[1] as TMethodApi; return put(apiActions.request.build(requestId, moduleId, methodId, requestData)); }<|fim▁end|>
import { apiActions } from "readium-desktop/common/redux/actions"; // eslint-disable-next-line local-rules/typed-redux-saga-use-typed-effects
<|file_name|>ics-convert.py<|end_file_name|><|fim▁begin|>#!/usr/bin/env python """Converts the .ics/.ical file into a FullCalendar compatiable JSON file FullCalendar uses a specific JSON format similar to iCalendar format. This script creates a JSON file containing renamed event components. Only the title, description, start/end time, and url data are used. Does not support repeating events. """ import sys import json __import__('pytz') __import__('icalendar') from icalendar import Calendar __author__ = "Andy Yin" __copyright__ = "Copyright (C) 2015, Andy Yin" __credits__ = ["Eddie Blundell"] __license__ = "MIT" __version__ = "1.0.0" __maintainer__ = "Andy Yin" __email__ = "[email protected]" __status__ = "Production" # quit if the arguments are incorrect, and prints a usage if (len(sys.argv) != 2 and len(sys.argv) != 3): print sys.argv[0] + ': illegal operation' print 'usage: python ' + sys.argv[0] + ' file [output]' exit(1) # default output filename (just adds .json extension on the given file) out_file = sys.argv[1] + '.json' if (len(sys.argv) == 3): # changes output filename to the 2nd arugment out_file = sys.argv[2] # opens the input .ics file and parses it as iCalendar Calendar object ics_file = open(sys.argv[1],'rb') ics_cal = Calendar.from_ical(ics_file.read()) # array of event information result = [] for component in ics_cal.walk(): if component.name == "VEVENT": # set containing all the events event = { 'title':component.get('summary'), 'backgroundColor':component.get('location'), 'description':component.get('description'), 'start':component.decoded('dtstart').isoformat(),<|fim▁hole|> # append to the result array result.append(event) ics_file.close() # saves the result using jsonify json_out = open(out_file, 'w') json_out.write(json.dumps(result, sort_keys = False, indent = 4)) json_out.close()<|fim▁end|>
'end':component.decoded('dtend').isoformat(), 'url':component.get('url') }
<|file_name|>cover.js<|end_file_name|><|fim▁begin|>var gulp = require('gulp'); var config = require('./config'); var mocha = require('gulp-mocha'); var istanbul = require('gulp-istanbul'); gulp.task('cover', function() { return gulp.src(config.tests.unit, { read: false }) .pipe(mocha({ reporter: 'dot', ui: 'mocha-given', require: ['coffee-script/register', 'should', 'should-sinon'] }))<|fim▁hole|><|fim▁end|>
.pipe(istanbul.writeReports()); });
<|file_name|>doc.go<|end_file_name|><|fim▁begin|><|fim▁hole|>// 临时素材管理. // // 永久素材管理在 material 模块; // 对于图文消息里的图片, 可以调用 base.UploadImage 或者 base.UploadImageFromReader 来上传. package media<|fim▁end|>
<|file_name|>Main.java<|end_file_name|><|fim▁begin|>package nl.pelagic.musicTree.flac2mp3.cli; import java.io.BufferedReader; import java.io.File; import java.io.IOException; import java.io.InputStreamReader; import java.io.PrintStream; import java.nio.file.Files; import java.util.HashSet; import java.util.List; import java.util.Map; import java.util.concurrent.atomic.AtomicBoolean; import java.util.logging.Level; import java.util.logging.Logger; import nl.pelagic.audio.conversion.flac2mp3.api.Flac2Mp3Configuration; import nl.pelagic.audio.conversion.flac2mp3.api.FlacToMp3; import nl.pelagic.audio.musicTree.configuration.api.MusicTreeConfiguration; import nl.pelagic.audio.musicTree.configuration.api.MusicTreeConstants; import nl.pelagic.audio.musicTree.syncer.api.Syncer; import nl.pelagic.audio.musicTree.util.MusicTreeHelpers; import nl.pelagic.musicTree.flac2mp3.cli.i18n.Messages; import nl.pelagic.shell.script.listener.api.ShellScriptListener; import nl.pelagic.shutdownhook.api.ShutdownHookParticipant; import nl.pelagic.util.file.FileUtils; import org.kohsuke.args4j.CmdLineException; import org.kohsuke.args4j.CmdLineParser; import org.osgi.framework.BundleContext; import org.osgi.service.component.annotations.Activate; import org.osgi.service.component.annotations.Component; import org.osgi.service.component.annotations.Deactivate; import org.osgi.service.component.annotations.Reference; /** * The main program that synchronises a flac tree into a mp3 tree or just * converts one or more flac files in mp3 files, based on a music tree * configuration */ @Component(property = { "main.thread=true" /* Signal the launcher that this is the main thread */ }) public class Main implements Runnable, ShutdownHookParticipant { /** the application logger name */ static private final String LOGGER_APPLICATION_NAME = "nl.pelagic"; //$NON-NLS-1$ /** the application logger level to allow */ static private final Level LOGGER_APPLICATION_LEVEL = Level.SEVERE; /** the jaudiotagger library logger name */ static private final String LOGGER_JAUDIOTAGGER_NAME = "org.jaudiotagger"; //$NON-NLS-1$ /** the jaudiotagger library logger level to allow */ static private final Level LOGGER_JAUDIOTAGGER_LEVEL = Level.SEVERE; /** the program name */ static final String PROGRAM_NAME = "flac2mp3"; //$NON-NLS-1$ /** the application logger */ private final Logger applicationLogger; /** the jaudiotagger library logger */ private final Logger jaudiotaggerLogger; /** the list of extension to use in the flac tree */ private final HashSet<String> extensionsList = new HashSet<>(); /** the filenames for covers to use in the flac tree */ private final HashSet<String> coversList = new HashSet<>(); /* * Construction */ /** * Default constructor */ public Main() { super(); /** * <pre> * 1=timestamp * 2=level * 3=logger * 4=class method * 5=message * 6=stack trace, preceded by a newline (if exception is present) * </pre> */ System.setProperty("java.util.logging.SimpleFormatter.format", "[%1$tF %1$tT] %4$10s %2$s : %5$s%6$s%n"); //$NON-NLS-1$ //$NON-NLS-2$ applicationLogger = Logger.getLogger(LOGGER_APPLICATION_NAME); applicationLogger.setLevel(LOGGER_APPLICATION_LEVEL); jaudiotaggerLogger = Logger.getLogger(LOGGER_JAUDIOTAGGER_NAME); jaudiotaggerLogger.setLevel(LOGGER_JAUDIOTAGGER_LEVEL); extensionsList.add(MusicTreeConstants.FLACEXTENSION); coversList.add(MusicTreeConstants.COVER); } /* * Consumed Services */ /** the shell script listener (optional) */ private ShellScriptListener shellScriptListener = null; /** * @param shellScriptListener the shellScriptListener to set */ @Reference void setShellScriptListener(ShellScriptListener shellScriptListener) { this.shellScriptListener = shellScriptListener; } /** the flac2Mp3 service */ private FlacToMp3 flacToMp3 = null; /** * @param flacToMp3 the flacToMp3 to set */ @Reference void setFlacToMp3(FlacToMp3 flacToMp3) { this.flacToMp3 = flacToMp3; } /** the syncer service */ private Syncer syncer = null; /** * @param syncer the syncer to set */ @Reference void setSyncer(Syncer syncer) { this.syncer = syncer; } /* * Command line arguments */ /** the launcher arguments property name */ static final String LAUNCHER_ARGUMENTS = "launcher.arguments"; //$NON-NLS-1$ /** the command line arguments */ private String[] args = null; /** * The bnd launcher provides access to the command line arguments via the * Launcher object. This object is also registered under Object. * * @param done unused * @param parameters the launcher parameters, which includes the command line * arguments */ @Reference void setDone(@SuppressWarnings("unused") Object done, Map<String, Object> parameters) { args = (String[]) parameters.get(LAUNCHER_ARGUMENTS); } /* * Bundle */ /** The setting name for the stayAlive property */ public static final String SETTING_STAYALIVE = "stayAlive"; //$NON-NLS-1$ /** true when the application should NOT automatically exit when done */ private boolean stayAlive = false; /** * Bundle activator * * @param bundleContext the bundle context */ @Activate void activate(BundleContext bundleContext) { String ex = bundleContext.getProperty(PROGRAM_NAME + "." + SETTING_STAYALIVE); //$NON-NLS-1$ if (ex != null) { stayAlive = Boolean.parseBoolean(ex); } } /** * Bundle deactivator */ @Deactivate void deactivate() { /* nothing to do */ } /* * Helpers */ /** * Read a filelist file into a list of entries to convert * * @param out the stream to print the error messages to * @param fileList the filelist file * @param entriesToConvert a list of files to convert, to which the files read * from the filelist file must be added * @return true when successful */ static boolean readFileList(PrintStream out, File fileList, List<String> entriesToConvert) { assert (out != null); assert (fileList != null); assert (entriesToConvert != null); if (!fileList.isFile()) { out.printf(Messages.getString("Main.8"), fileList.getPath()); //$NON-NLS-1$ return false; } try (BufferedReader reader = new BufferedReader(new InputStreamReader(Files.newInputStream(fileList.toPath()), "UTF-8"))) { //$NON-NLS-1$ String line = null; while ((line = reader.readLine()) != null) { /* skip empty lines */ if (line.trim().isEmpty()) { continue; } entriesToConvert.add(line); } } catch (IOException e) { /* can't be covered in a test */ out.printf(Messages.getString("Main.11"), fileList, e.getLocalizedMessage()); //$NON-NLS-1$ return false; } return true; } /** * Validate the entry to convert to filter out non-existing directories and * files. An entry to convert must exist and be below the flac base directory. * * @param out the stream to print the error messages to * @param musicTreeConfiguration the music tree configuration * @param entryToConvert the entry to convert * @return true when validation is successful */ static boolean validateEntryToConvert(PrintStream out, MusicTreeConfiguration musicTreeConfiguration, File entryToConvert) { assert (out != null); assert (musicTreeConfiguration != null); assert (entryToConvert != null); /* check that the entry exists */ if (!entryToConvert.exists()) { out.printf(Messages.getString("Main.5"), entryToConvert.getPath()); //$NON-NLS-1$ return false; } /* * check that entry is below the flac base directory so that it doesn't * escape the base directory by doing a ../../.. */ if (!FileUtils.isFileBelowDirectory(musicTreeConfiguration.getFlacBaseDir(), entryToConvert, true)) { out.printf(Messages.getString("Main.6"), //$NON-NLS-1$ entryToConvert.getPath(), musicTreeConfiguration.getFlacBaseDir().getPath()); return false; } return true; } /** * Convert a flac file into an mp3 file. * * @param err the stream to print to * @param flac2Mp3Configuration the conversion configuration. When null then * the default configuration is used. * @param musicTreeConfiguration the music tree configuration * @param simulate true to simulate conversion * @param fileToConvert the flac file to convert * * @return true when successful */ boolean convertFile(PrintStream err, Flac2Mp3Configuration flac2Mp3Configuration, MusicTreeConfiguration musicTreeConfiguration, boolean simulate, File fileToConvert) { assert (err != null); assert (flac2Mp3Configuration != null); assert (musicTreeConfiguration != null); assert (fileToConvert != null); assert (fileToConvert.isFile()); File mp3File = MusicTreeHelpers.flacFileToMp3File(musicTreeConfiguration, fileToConvert); if (mp3File == null) { err.printf(Messages.getString("Main.12"), fileToConvert.getPath(), //$NON-NLS-1$ musicTreeConfiguration.getMp3BaseDir().getPath()); return false; } boolean doConversion = !mp3File.exists() || (fileToConvert.lastModified() > mp3File.lastModified()); if (!doConversion) { return true; } boolean converted = false; try { converted = flacToMp3.convert(flac2Mp3Configuration, fileToConvert, mp3File, simulate); if (!converted) { err.printf(Messages.getString("Main.1"), fileToConvert.getPath()); //$NON-NLS-1$ } } catch (IOException e) { converted = false; err.printf(Messages.getString("Main.2"), fileToConvert.getPath(), e.getLocalizedMessage()); //$NON-NLS-1$ } return converted; } /** * Stay alive, if needed (which is when the component has a SETTING_STAYALIVE * property set to true). * * @param err the stream to print a 'staying alive' message to */ void stayAlive(PrintStream err) { if (!stayAlive) { return; } err.printf(Messages.getString("Main.7")); //$NON-NLS-1$ try { Thread.sleep(Long.MAX_VALUE); } catch (InterruptedException e) { /* swallow */ } } /* * ShutdownHookParticipant */ /** true when we have to stop */ private AtomicBoolean stop = new AtomicBoolean(false); @Override public void shutdownHook() { stop.set(true); } /* * Main */ /** * Run the main program * * @param err the stream to print errors to * @return true when successful */ boolean doMain(PrintStream err) { if (args == null) { /* * the launcher didn't set our command line options so set empty arguments * (use defaults) */ args = new String[0]; } /* * Parse the command line */ CommandLineOptions commandLineOptions = new CommandLineOptions(); CmdLineParser parser = new CmdLineParser(commandLineOptions); try { parser.parseArgument(args); } catch (CmdLineException e) { err.printf(Messages.getString("Main.4"), e.getLocalizedMessage()); //$NON-NLS-1$ commandLineOptions.setErrorReported(true); } /* * Process command-line options */ /* print usage when so requested and exit */ if (commandLineOptions.isHelp() || commandLineOptions.isErrorReported()) { try { /* can't be covered by a test */ int cols = Integer.parseInt(System.getenv("COLUMNS")); //$NON-NLS-1$ if (cols > 80) { parser.getProperties().withUsageWidth(cols); } } catch (NumberFormatException e) { /* swallow, can't be covered by a test */ } CommandLineOptions.usage(err, PROGRAM_NAME, parser); return false; } /* * Setup verbose modes in the shell script listener */ shellScriptListener.setVerbose(commandLineOptions.isVerbose(), commandLineOptions.isExtraVerbose(), commandLineOptions.isQuiet()); /* * Setup & validate the music tree configuration */ MusicTreeConfiguration musicTreeConfiguration = new MusicTreeConfiguration(commandLineOptions.getFlacBaseDir(), commandLineOptions.getMp3BaseDir()); List<String> errors = musicTreeConfiguration.validate(true); if (errors != null) { for (String error : errors) { err.println(error); } return false; } /* * Setup & validate the flac2mp3 configuration */ Flac2Mp3Configuration flac2Mp3Configuration = new Flac2Mp3Configuration(); flac2Mp3Configuration.setFlacExecutable(commandLineOptions.getFlacExecutable().getPath()); flac2Mp3Configuration.setLameExecutable(commandLineOptions.getLameExecutable().getPath()); flac2Mp3Configuration.setFlacOptions(commandLineOptions.getFlacOptions()); flac2Mp3Configuration.setLameOptions(commandLineOptions.getLameOptions()); flac2Mp3Configuration.setUseId3V1Tags(commandLineOptions.isUseID3v1()); flac2Mp3Configuration.setUseId3V24Tags(commandLineOptions.isUseID3v24()); flac2Mp3Configuration.setForceConversion(commandLineOptions.isForceConversion()); flac2Mp3Configuration.setRunFlacLame(!commandLineOptions.isDoNotRunFlacAndLame()); flac2Mp3Configuration.setCopyTag(!commandLineOptions.isDoNotCopyTag()); flac2Mp3Configuration.setCopyTimestamp(!commandLineOptions.isDoNotCopyTimestamp()); errors = flac2Mp3Configuration.validate(); if (errors != null) { /* can't be covered by a test */ for (String error : errors) { err.println(error); } return false; } /* * Setup the entries to convert: first get them from the command-line (if * specified) and then add those in the file list (if set) */ List<String> entriesToConvert = commandLineOptions.getEntriesToConvert(); File fileList = commandLineOptions.getFileList(); if (fileList != null) { readFileList(err, fileList, entriesToConvert); } if (entriesToConvert.isEmpty()) { /* * no entries to convert, so default to the flac base directory: sync the * whole tree */ entriesToConvert.add(musicTreeConfiguration.getFlacBaseDir().getAbsolutePath()); } /* * Run */ boolean result = true; for (String entryToConvert : entriesToConvert) { if (stop.get()) { break; } File entryToConvertFile = new File(entryToConvert); boolean validationResult = validateEntryToConvert(err, musicTreeConfiguration, entryToConvertFile); if (validationResult) { if (entryToConvertFile.isDirectory()) { result = result && syncer.syncFlac2Mp3(flac2Mp3Configuration, musicTreeConfiguration, entryToConvertFile, extensionsList, coversList, commandLineOptions.isSimulate()); } else if (entryToConvertFile.isFile()) { result = result && convertFile(err, flac2Mp3Configuration, musicTreeConfiguration, commandLineOptions.isSimulate(), entryToConvertFile); } else { /* can't be covered by a test */ err.printf(Messages.getString("Main.3"), entryToConvert); //$NON-NLS-1$ } } else { result = false; } } return result; } /* * Since we're registered as a Runnable with the main.thread property we get * called when the system is fully initialised. */ @Override public void run() { boolean success = doMain(System.err); stayAlive(System.err); if (!success) { /* can't be covered by a test */ System.exit(1);<|fim▁hole|><|fim▁end|>
} } }
<|file_name|>build.rs<|end_file_name|><|fim▁begin|>extern crate gcc; use std::env; pub fn main() { let target = env::var("TARGET").unwrap(); let os = if target.contains("linux") { "LINUX" } else if target.contains("darwin") { "DARWIN" } else { "UNKNOWN" }; let mut config = gcc::Config::new(); for file in &["src/const.c", "src/sizes.c"] { config.file(file); } config.define(os, None); <|fim▁hole|> config.compile("libnixtest.a"); } /* use std::env; use std::process::Command; pub fn main() { let root = env::var("CARGO_MANIFEST_DIR").unwrap(); let make = root.clone() + "/Makefile"; let src = root.clone() + "/src"; let out = env::var("OUT_DIR").unwrap(); let target = env::var("TARGET").unwrap(); let os = if target.contains("linux") { "LINUX" } else if target.contains("darwin") { "DARWIN" } else { "UNKNOWN" }; let res = Command::new("make") .arg("-f").arg(&make) .current_dir(&out) .env("VPATH", &src) .env("OS", os) .spawn().unwrap() .wait().unwrap(); assert!(res.success()); println!("cargo:rustc-flags=-L {}/", out); } */<|fim▁end|>
<|file_name|>__init__.py<|end_file_name|><|fim▁begin|># Licensed under a 3-clause BSD style license - see LICENSE.rst<|fim▁hole|>from .ui import * from .mpl_style import *<|fim▁end|>
from .stretch import * from .interval import * from .transform import *
<|file_name|>watchedfolders.py<|end_file_name|><|fim▁begin|># Miro - an RSS based video player application # Copyright (C) 2005, 2006, 2007, 2008, 2009, 2010, 2011 # Participatory Culture Foundation # # This program is free software; you can redistribute it and/or modify # it under the terms of the GNU General Public License as published by # the Free Software Foundation; either version 2 of the License, or # (at your option) any later version. # # This program is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the # GNU General Public License for more details. # # You should have received a copy of the GNU General Public License # along with this program; if not, write to the Free Software # Foundation, Inc., 51 Franklin St, Fifth Floor, Boston, MA 02110-1301 USA # # In addition, as a special exception, the copyright holders give # permission to link the code of portions of this program with the OpenSSL # library. # # You must obey the GNU General Public License in all respects for all of # the code used other than OpenSSL. If you modify file(s) with this # exception, you may extend this exception to your version of the file(s), # but you are not obligated to do so. If you do not wish to do so, delete # this exception statement from your version. If you delete this exception # statement from all source files in the program, then also delete it here. """watchedsfolders.py -- Manages tracking watched folders. """ from miro import messages from miro import signals from miro.plat.frontends.widgets import widgetset from miro.plat.utils import filename_to_unicode class WatchedFolderManager(signals.SignalEmitter): """Manages tracking watched folders. Attributes: model -- TableModel object that contains the current list of watched folders. It has 3 columns: id (integer), path (text) and visible (boolean). Signals: changed -- The list of watched folders has changed """ def __init__(self): signals.SignalEmitter.__init__(self, 'changed') self.model = widgetset.TableModel('integer', 'text', 'boolean') self._iter_map = {} def handle_watched_folder_list(self, info_list): """Handle the WatchedFolderList message.""" for info in info_list: iter = self.model.append(info.id, filename_to_unicode(info.path), info.visible) self._iter_map[info.id] = iter self.emit('changed') def handle_watched_folders_changed(self, added, changed, removed): """Handle the WatchedFoldersChanged message.""" self.handle_watched_folder_list(added) for info in changed: iter = self._iter_map[info.id] self.model.update_value(iter, 1, filename_to_unicode(info.path)) self.model.update_value(iter, 2, info.visible) for id in removed: iter = self._iter_map.pop(id) self.model.remove(iter) self.emit('changed') def change_visible(self, id_, visible):<|fim▁hole|> def remove(self, id_): """Remove a watched folder.""" messages.DeleteWatchedFolder(id_).send_to_backend() def add(self, path): """Add a new watched folder. It will be initially visible.""" messages.NewWatchedFolder(path).send_to_backend()<|fim▁end|>
"""Change if a watched folder is visible or not.""" messages.SetWatchedFolderVisible(id_, visible).send_to_backend()
<|file_name|>entry.py<|end_file_name|><|fim▁begin|>import os from inspect import signature from . import db from . import settings class Entry: def __init__(self, id_=None, author=None, date=None, body=None, body_html=None, url=None, plus=None, media_url=None, tags=None, is_nsfw=None, entry_id=None, type_=None): self.id_ = id_ self.author = author<|fim▁hole|> self.plus = plus self.media_url = media_url self.tags = tags self.is_nsfw = is_nsfw self.entry_id = entry_id # only for comment self.type_ = type_ def __iter__(self): return self.attrs_gen() def attrs_gen(self): attrs = list(signature(self.__init__).parameters.keys()) # attributes from __init__() return (getattr(self, attr) for attr in attrs[:11]) def __str__(self): if self.entry_id: return '{}_{}'.format(self.entry_id, self.id_) return str(self.id_) def download_info(self): return { 'id_': self.__str__(), 'media_url': self.media_url, 'is_nsfw': self.is_nsfw, 'local_file_path': self.local_file_path, } @property def comments_count(self): if not self.entry_id: # if entry_id is not none it's a comment return db.DB.count_comments(self.id_) @property def media_ext(self): if self.media_url: _, ext = os.path.splitext(self.media_url) if len(ext) > 4 and '?' in ext: # fix for urls with '?' ext = ext.split('?')[0] elif not ext and 'gfycat.com' in self.media_url: ext = '.webm' return ext else: return None @property def local_file_path(self): path = settings.FILES_DIR_NAME ext = self.media_ext if self.media_url and ext: if self.is_nsfw: path = os.path.join(path, settings.NSFW_DIR_NAME) if self.entry_id: # it's a comment return os.path.join(path, settings.COMMENTS_DIR_NAME, '{}_{}{}'.format(self.entry_id, self.id_, ext)) return os.path.join(path, '{}{}'.format(self.id_, ext)) return ''<|fim▁end|>
self.date = date self.body = body self.body_html = body_html self.url = url
<|file_name|>Fp64Operand.java<|end_file_name|><|fim▁begin|>/** * Copyright (C) 2010-2017 Gordon Fraser, Andrea Arcuri and EvoSuite * contributors * * This file is part of EvoSuite. * * EvoSuite is free software: you can redistribute it and/or modify it * under the terms of the GNU Lesser General Public License as published * by the Free Software Foundation, either version 3.0 of the License, or * (at your option) any later version. * * EvoSuite is distributed in the hope that it will be useful, but * WITHOUT ANY WARRANTY; without even the implied warranty of * MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the GNU * Lesser Public License for more details. * * You should have received a copy of the GNU Lesser General Public * License along with EvoSuite. If not, see <http://www.gnu.org/licenses/>. */ package org.evosuite.symbolic.vm; import org.evosuite.symbolic.expr.fp.RealValue; /** * * @author galeotti * */ public final class Fp64Operand implements DoubleWordOperand, RealOperand { private final RealValue realExpr; <|fim▁hole|> public RealValue getRealExpression() { return realExpr; } @Override public String toString() { return realExpr.toString(); } }<|fim▁end|>
public Fp64Operand(RealValue realExpr) { this.realExpr = realExpr; }
<|file_name|>ap.js<|end_file_name|><|fim▁begin|>(function () { angular.module('travelApp', ['toursApp'])<|fim▁hole|> var pattern = /Date\(([^)]+)\)/; var results = pattern.exec(value); var dt = new Date(parseFloat(results[1])); return dt; } }) .filter('myDateFormat', [ 'dateParse', function (dateParse) { return function (x) { return dateParse.myDateParse(x); }; } ]); })();<|fim▁end|>
.service('dateParse', function () { this.myDateParse = function (value) {
<|file_name|>click-with-callback.js<|end_file_name|><|fim▁begin|>// Generated by CoffeeScript 1.10.0 (function() {<|fim▁hole|> console.log("some_button clicked!"); return event.preventDefault(); }); })(jQuery); }).call(this);<|fim▁end|>
(function($) { return $(".some_button").on("click", function(event) {
<|file_name|>network.cc<|end_file_name|><|fim▁begin|>#include "network.h" namespace network { bool can_reach_host (char const* host) { bool res = false; if(SCNetworkReachabilityRef ref = SCNetworkReachabilityCreateWithName(kCFAllocatorDefault, host)) { SCNetworkReachabilityFlags flags; if(SCNetworkReachabilityGetFlags(ref, &flags)) { if(flags & kSCNetworkReachabilityFlagsReachable)<|fim▁hole|> CFRelease(ref); } return res; } } /* network */<|fim▁end|>
res = true; }
<|file_name|>tools.py<|end_file_name|><|fim▁begin|>""" Copyright (C) 2018 MuadDib ---------------------------------------------------------------------------- "THE BEER-WARE LICENSE" (Revision 42): @tantrumdev wrote this file. As long as you retain this notice you can do whatever you want with this stuff. If we meet some day, and you think this stuff is worth it, you can buy him a beer in return. - Muad'Dib ---------------------------------------------------------------------------- Overview: Drop this PY in the plugins folder, and use whatever tools below you want. Version: 2018.6.8 - Added Streamango and Streamcherry pairing sites - Added <adult> tag to hide menu items unless an addon setting enabled it (see code for setting id to use in your settings.xml) 2018.5.25 - Added <pairwith> tags - Can use pairlist to show all sites, or specific entry from PAIR_LIST to load that site from menu - Added <trailer> tag support to load your custom YT trailer (via plugin url) for non-imdb items 2018.5.1a - Added <mode> and <modeurl> tags (used together in same item) 2018.5.1 - Initial Release XML Explanations: Tags: <heading></heading> - Displays the entry as normal, but performs no action (not a directory or "item") <mysettings>0/0</mysettings> - Opens settings dialog to the specified Tab and section (0 indexed) <pairwith></pairwith> - Used for pairing with sites. See list below of supported sites with this plugin <trailer>plugin://plugin.video.youtube/play/?video_id=ChA0qNHV1D4</trailer> Usage Examples: <item> <title>[COLOR limegreen]Don't forget to folow me on twitter @tantrumdev ![/COLOR]</title> <heading></heading> </item> <item> <title>JEN: Customization</title> <mysettings>0/0</mysettings> <info>Open the Settings for the addon on the Customization tab</info> </item> <item> <title>Pair With Sites</title> <pairwith>pairlist</pairwith> </item> <item> <title>Pair Openload</title> <pairwith>openload</pairwith> </item> <item> <title>Dune (1984)</title> <trailer>plugin://plugin.video.youtube/play/?video_id=ChA0qNHV1D4</trailer> <info>Provides the Trailer context link for this movie when Metadata is DISABLED in your addon.</info> </item> <item> <title>JEN: General</title> <mysettings>1/0</mysettings> <info>Open the Settings for the addon on the General tab</info> </item> <item> <title>Custom Mode</title> <mode>Whatever</mode> <modeurl>query=Iwant</modeurl> <info>Sets a specific Mode for the menu item, to utilize Jen modes not normally accessible. Setting modeurl passes a custom built url= variable to go with it</info> </item> """ import collections,requests,re,os,traceback,webbrowser import koding import __builtin__ import xbmc,xbmcaddon,xbmcgui from koding import route from resources.lib.plugin import Plugin from resources.lib.util.context import get_context_items from resources.lib.util.xml import JenItem, JenList, display_list from unidecode import unidecode addon_id = xbmcaddon.Addon().getAddonInfo('id') this_addon = xbmcaddon.Addon(id=addon_id) addon_fanart = xbmcaddon.Addon().getAddonInfo('fanart') addon_icon = xbmcaddon.Addon().getAddonInfo('icon') addon_path = xbmcaddon.Addon().getAddonInfo('path') PAIR_LIST = [ ("openload", "https://olpair.com/pair"), ("streamango", "https://streamango.com/pair"), ("streamcherry", "https://streamcherry.com/pair"), ("the_video_me", "https://thevideo.us/pair"), ("vid_up_me", "https://vidup.me/pair"), ("vshare", "http://vshare.eu/pair"), ("flashx", "https://www.flashx.tv/?op=login&redirect=https://www.flashx.tv/pairing.php") ] class JenTools(Plugin): name = "jentools" priority = 200 def process_item(self, item_xml): result_item = None if "<heading>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': "HEADING", 'url': item.get("heading", ""), 'folder': False, 'imdb': "0", 'content': "files", 'season': "0", 'episode': "0", 'info': {}, 'year': "0", 'context': get_context_items(item), "summary": item.get("summary", None) } return result_item elif "<mysettings>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': "MYSETTINGS", 'url': item.get("mysettings", ""), 'folder': False, 'imdb': "0", 'content': "files", 'season': "0", 'episode': "0", 'info': {}, 'year': "0", 'context': get_context_items(item), "summary": item.get("summary", None) } return result_item elif "<adult>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': "PASSREQ", 'url': item.get("adult", ""), 'folder': True, 'imdb': "0", 'content': "files", 'season': "0", 'episode': "0", 'info': {}, 'year': "0", 'context': get_context_items(item), "summary": item.get("summary", None) } return result_item elif "<mode>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': item.get("mode", ""), 'url': item.get("modeurl", ""), 'folder': True, 'imdb': "0", 'content': "files",<|fim▁hole|> 'context': get_context_items(item), "summary": item.get("summary", None) } return result_item elif "<pairwith>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': "PAIRWITH", 'url': item.get("pairwith", ""), 'folder': False, 'imdb': "0", 'content': "files", 'season': "0", 'episode': "0", 'info': {}, 'year': "0", 'context': get_context_items(item), "summary": item.get("summary", None) } return result_item elif "<trailer>" in item_xml: item = JenItem(item_xml) result_item = { 'label': item["title"], 'icon': item.get("thumbnail", addon_icon), 'fanart': item.get("fanart", addon_fanart), 'mode': "PAIRWITH", 'url': item.get("pairwith", ""), 'folder': False, 'imdb': "0", 'content': "files", 'season': "0", 'episode': "0", 'info': {}, 'year': "0", 'context': get_context_items(item), "summary": item.get("summary", None) } result_item["info"]["trailer"] = item.get("trailer", None) return result_item @route(mode='HEADING') def heading_handler(): try: quit() except: pass @route(mode="MYSETTINGS", args=["url"]) def mysettings_handler(query): try: xbmc.executebuiltin('Dialog.Close(busydialog)') xbmc.executebuiltin('Addon.OpenSettings(%s)' % addon_id) c, f = query.split('/') xbmc.executebuiltin('SetFocus(%i)' % (int(c) + 100)) xbmc.executebuiltin('SetFocus(%i)' % (int(f) + 200)) except: return @route(mode="PASSREQ", args=["url"]) def password_handler(url): adult_xml = '' try: the_setting = this_addon.getSetting('adult_stuff') if the_setting == None or the_setting == '': the_setting = 'false' xbmcaddon.Addon().setSetting('adult_stuff', str(the_setting)) if the_setting == 'false': adult_xml += "<item>"\ " <title>[COLOR yellow]This menu is not enabled[/COLOR]</title>"\ " <heading></heading>"\ " <thumbnail>https://nsx.np.dl.playstation.net/nsx/material/c/ce432e00ce97a461b9a8c01ce78538f4fa6610fe-1107562.png</thumbnail>"\ "</item>" jenlist = JenList(adult_xml) display_list(jenlist.get_list(), jenlist.get_content_type()) return except: return sep_list = url.decode('base64').split('|') dec_pass = sep_list[0] xml_loc = sep_list[1] input = '' keyboard = xbmc.Keyboard(input, '[COLOR red]Are you worthy?[/COLOR]') keyboard.doModal() if keyboard.isConfirmed(): input = keyboard.getText() if input == dec_pass: if 'http' in xml_loc: adult_xml = requests.get(xml_loc).content else: import xbmcvfs xml_loc = xml_loc.replace('file://', '') xml_file = xbmcvfs.File(os.path.join(addon_path, "xml", xml_loc)) adult_xml = xml_file.read() xml_file.close() else: adult_xml += "<dir>"\ " <title>[COLOR yellow]Wrong Answer! You are not worthy[/COLOR]</title>"\ " <thumbnail>https://nsx.np.dl.playstation.net/nsx/material/c/ce432e00ce97a461b9a8c01ce78538f4fa6610fe-1107562.png</thumbnail>"\ "</dir>" jenlist = JenList(adult_xml) display_list(jenlist.get_list(), jenlist.get_content_type()) @route(mode="PAIRWITH", args=["url"]) def pairing_handler(url): try: site = '' if 'pairlist' in url: names = [] for item in PAIR_LIST: the_title = 'PAIR %s' % (item[0].replace('_', ' ').capitalize()) names.append(the_title) selected = xbmcgui.Dialog().select('Select Site',names) if selected == -1: return # If you add [COLOR] etc to the title stuff in names loop above, this will strip all of that out and make it usable here pair_item = re.sub('\[.*?]','',names[selected]).replace('Pair for ', '').replace(' ', '_').lower() for item in PAIR_LIST: if str(item[0]) == pair_item: site = item[1] break else: for item in PAIR_LIST: if str(item[0]) == url: site = item[1] break check_os = platform() if check_os == 'android': spam_time = xbmc.executebuiltin('StartAndroidActivity(,android.intent.action.VIEW,,%s)' % (site)) elif check_os == 'osx': os.system("open -a /Applications/Safari.app %s") % (site) else: spam_time = webbrowser.open(site) except: failure = traceback.format_exc() xbmcgui.Dialog().textviewer('Exception',str(failure)) pass def platform(): if xbmc.getCondVisibility('system.platform.android'): return 'android' elif xbmc.getCondVisibility('system.platform.linux'): return 'linux' elif xbmc.getCondVisibility('system.platform.windows'): return 'windows' elif xbmc.getCondVisibility('system.platform.osx'): return 'osx' elif xbmc.getCondVisibility('system.platform.atv2'): return 'atv2' elif xbmc.getCondVisibility('system.platform.ios'): return 'ios'<|fim▁end|>
'season': "0", 'episode': "0", 'info': {}, 'year': "0",
<|file_name|>0001_initial.py<|end_file_name|><|fim▁begin|># encoding: utf-8 import datetime from south.db import db from south.v2 import SchemaMigration from django.db import models class Migration(SchemaMigration): def forwards(self, orm): # Adding model 'ProductType' db.create_table('inventory_producttype', ( ('id', self.gf('django.db.models.fields.AutoField')(primary_key=True)), )) db.send_create_signal('inventory', ['ProductType']) # Adding model 'Product' db.create_table('inventory_product', ( ('id', self.gf('django.db.models.fields.AutoField')(primary_key=True)), ('shop', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['shops.Shop'])), ('title', self.gf('django.db.models.fields.CharField')(max_length=200)), ('description', self.gf('django.db.models.fields.TextField')()), ('category', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['market.MarketCategory'])), ('subcategory', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['market.MarketSubCategory'])), ('date_time', self.gf('django.db.models.fields.DateTimeField')(auto_now_add=True, blank=True)), ('weight', self.gf('django.db.models.fields.DecimalField')(default='0', max_digits=11, decimal_places=2)), ('type', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['inventory.ProductType'], null=True, blank=True)), )) db.send_create_signal('inventory', ['Product']) # Adding model 'Coin' db.create_table('inventory_coin', ( ('producttype_ptr', self.gf('django.db.models.fields.related.OneToOneField')(to=orm['inventory.ProductType'], unique=True, primary_key=True)), ('category', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['market.MarketCategory'], null=True, blank=True)), ('subcategory', self.gf('django.db.models.fields.related.ForeignKey')(to=orm['market.MarketSubCategory'], null=True, blank=True)), ('country_code', self.gf('django.db.models.fields.CharField')(default='us', max_length=2)), ('pcgs_number', self.gf('django.db.models.fields.IntegerField')(null=True, blank=True)), ('description', self.gf('django.db.models.fields.TextField')(default='', blank='')), ('year_issued', self.gf('django.db.models.fields.CharField')(default='', max_length=24, blank='')), ('actual_year', self.gf('django.db.models.fields.CharField')(default='', max_length=24, blank='')), ('denomination', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('major_variety', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('die_variety', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('prefix', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('suffix', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('sort_order', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('heading', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('holder_variety', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('holder_variety_2', self.gf('django.db.models.fields.CharField')(default='', max_length=60, blank='')), ('additional_data', self.gf('django.db.models.fields.TextField')(default='', blank='')), ('last_update', self.gf('django.db.models.fields.DateTimeField')(auto_now=True, blank=True)), )) db.send_create_signal('inventory', ['Coin']) def backwards(self, orm): # Deleting model 'ProductType' db.delete_table('inventory_producttype') # Deleting model 'Product' db.delete_table('inventory_product') # Deleting model 'Coin' db.delete_table('inventory_coin') models = { 'auth.group': { 'Meta': {'object_name': 'Group'}, 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'name': ('django.db.models.fields.CharField', [], {'unique': 'True', 'max_length': '80'}), 'permissions': ('django.db.models.fields.related.ManyToManyField', [], {'to': "orm['auth.Permission']", 'symmetrical': 'False', 'blank': 'True'}) }, 'auth.permission': { 'Meta': {'unique_together': "(('content_type', 'codename'),)", 'object_name': 'Permission'}, 'codename': ('django.db.models.fields.CharField', [], {'max_length': '100'}), 'content_type': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['contenttypes.ContentType']"}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '50'}) }, 'auth.user': { 'Meta': {'object_name': 'User'}, 'date_joined': ('django.db.models.fields.DateTimeField', [], {'default': 'datetime.datetime.now'}), 'email': ('django.db.models.fields.EmailField', [], {'max_length': '75'}), 'first_name': ('django.db.models.fields.CharField', [], {'max_length': '30', 'blank': 'True'}), 'groups': ('django.db.models.fields.related.ManyToManyField', [], {'to': "orm['auth.Group']", 'symmetrical': 'False', 'blank': 'True'}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'is_active': ('django.db.models.fields.BooleanField', [], {'default': 'True', 'blank': 'True'}), 'is_staff': ('django.db.models.fields.BooleanField', [], {'default': 'False', 'blank': 'True'}), 'is_superuser': ('django.db.models.fields.BooleanField', [], {'default': 'False', 'blank': 'True'}), 'last_login': ('django.db.models.fields.DateTimeField', [], {'default': 'datetime.datetime.now'}), 'last_name': ('django.db.models.fields.CharField', [], {'max_length': '30', 'blank': 'True'}), 'password': ('django.db.models.fields.CharField', [], {'max_length': '128'}), 'user_permissions': ('django.db.models.fields.related.ManyToManyField', [], {'to': "orm['auth.Permission']", 'symmetrical': 'False', 'blank': 'True'}), 'username': ('django.db.models.fields.CharField', [], {'unique': 'True', 'max_length': '32'}) }, 'contenttypes.contenttype': { 'Meta': {'unique_together': "(('app_label', 'model'),)", 'object_name': 'ContentType', 'db_table': "'django_content_type'"}, 'app_label': ('django.db.models.fields.CharField', [], {'max_length': '100'}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'model': ('django.db.models.fields.CharField', [], {'max_length': '100'}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '100'}) }, 'inventory.coin': { 'Meta': {'object_name': 'Coin', '_ormbases': ['inventory.ProductType']}, 'actual_year': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '24', 'blank': "''"}), 'additional_data': ('django.db.models.fields.TextField', [], {'default': "''", 'blank': "''"}), 'category': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketCategory']", 'null': 'True', 'blank': 'True'}), 'country_code': ('django.db.models.fields.CharField', [], {'default': "'us'", 'max_length': '2'}), 'denomination': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'description': ('django.db.models.fields.TextField', [], {'default': "''", 'blank': "''"}), 'die_variety': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'heading': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'holder_variety': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'holder_variety_2': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'last_update': ('django.db.models.fields.DateTimeField', [], {'auto_now': 'True', 'blank': 'True'}), 'major_variety': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'pcgs_number': ('django.db.models.fields.IntegerField', [], {'null': 'True', 'blank': 'True'}), 'prefix': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'producttype_ptr': ('django.db.models.fields.related.OneToOneField', [], {'to': "orm['inventory.ProductType']", 'unique': 'True', 'primary_key': 'True'}), 'sort_order': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'subcategory': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketSubCategory']", 'null': 'True', 'blank': 'True'}), 'suffix': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '60', 'blank': "''"}), 'year_issued': ('django.db.models.fields.CharField', [], {'default': "''", 'max_length': '24', 'blank': "''"}) }, 'inventory.product': { 'Meta': {'object_name': 'Product'}, 'category': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketCategory']"}), 'date_time': ('django.db.models.fields.DateTimeField', [], {'auto_now_add': 'True', 'blank': 'True'}), 'description': ('django.db.models.fields.TextField', [], {}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'shop': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['shops.Shop']"}), 'subcategory': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketSubCategory']"}), 'title': ('django.db.models.fields.CharField', [], {'max_length': '200'}),<|fim▁hole|> 'weight': ('django.db.models.fields.DecimalField', [], {'default': "'0'", 'max_digits': '11', 'decimal_places': '2'}) }, 'inventory.producttype': { 'Meta': {'object_name': 'ProductType'}, 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}) }, 'market.marketcategory': { 'Meta': {'object_name': 'MarketCategory'}, 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'marketplace': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketPlace']"}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '60'}), 'order': ('django.db.models.fields.IntegerField', [], {'default': '255'}), 'slug': ('django.db.models.fields.SlugField', [], {'unique': 'True', 'max_length': '60', 'db_index': 'True'}) }, 'market.marketplace': { 'Meta': {'object_name': 'MarketPlace'}, 'base_domain': ('django.db.models.fields.CharField', [], {'unique': 'True', 'max_length': '128'}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '92'}), 'slug': ('django.db.models.fields.SlugField', [], {'unique': 'True', 'max_length': '92', 'db_index': 'True'}), 'template_prefix': ('django.db.models.fields.SlugField', [], {'unique': 'True', 'max_length': '92', 'db_index': 'True'}), 'title': ('django.db.models.fields.CharField', [], {'max_length': '92'}) }, 'market.marketsubcategory': { 'Meta': {'unique_together': "(('parent', 'slug'),)", 'object_name': 'MarketSubCategory'}, 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'marketplace': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketPlace']"}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '60'}), 'order': ('django.db.models.fields.IntegerField', [], {'default': '255'}), 'parent': ('django.db.models.fields.related.ForeignKey', [], {'blank': 'True', 'related_name': "'subcategories'", 'null': 'True', 'to': "orm['market.MarketCategory']"}), 'slug': ('django.db.models.fields.SlugField', [], {'max_length': '60', 'db_index': 'True'}) }, 'shops.shop': { 'Meta': {'object_name': 'Shop'}, 'admin': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['auth.User']"}), 'bids': ('django.db.models.fields.IntegerField', [], {'default': '0'}), 'date_time': ('django.db.models.fields.DateTimeField', [], {'auto_now_add': 'True', 'blank': 'True'}), 'id': ('django.db.models.fields.AutoField', [], {'primary_key': 'True'}), 'location': ('django.db.models.fields.CharField', [], {'default': "'39.29038,-76.61219'", 'max_length': '255'}), 'marketplace': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['market.MarketPlace']"}), 'name': ('django.db.models.fields.CharField', [], {'max_length': '60'}), 'views': ('django.db.models.fields.IntegerField', [], {'default': '0'}) } } complete_apps = ['inventory']<|fim▁end|>
'type': ('django.db.models.fields.related.ForeignKey', [], {'to': "orm['inventory.ProductType']", 'null': 'True', 'blank': 'True'}),
<|file_name|>data_store.rs<|end_file_name|><|fim▁begin|>// Copyright (c) The Diem Core Contributors // SPDX-License-Identifier: Apache-2.0 use crate::{ loaded_data::runtime_types::Type, values::{GlobalValue, Value}, }; use move_core_types::{account_address::AccountAddress, language_storage::ModuleId}; use vm::errors::{PartialVMResult, VMResult}; /// Provide an implementation for bytecodes related to data with a given data store. /// /// The `DataStore` is a generic concept that includes both data and events. /// A default implementation of the `DataStore` is `TransactionDataCache` which provides /// an in memory cache for a given transaction and the atomic transactional changes<|fim▁hole|> // StateStore operations // --- /// Try to load a resource from remote storage and create a corresponding GlobalValue /// that is owned by the data store. fn load_resource( &mut self, addr: AccountAddress, ty: &Type, ) -> PartialVMResult<&mut GlobalValue>; /// Get the serialized format of a `CompiledModule` given a `ModuleId`. fn load_module(&self, module_id: &ModuleId) -> VMResult<Vec<u8>>; /// Publish a module. fn publish_module(&mut self, module_id: &ModuleId, blob: Vec<u8>) -> VMResult<()>; /// Check if this module exists. fn exists_module(&self, module_id: &ModuleId) -> VMResult<bool>; // --- // EventStore operations // --- /// Emit an event to the EventStore fn emit_event( &mut self, guid: Vec<u8>, seq_num: u64, ty: Type, val: Value, ) -> PartialVMResult<()>; }<|fim▁end|>
/// proper of a script execution (transaction). pub trait DataStore { // ---
<|file_name|>0001_initial.py<|end_file_name|><|fim▁begin|># -*- coding: utf-8 -*- from __future__ import unicode_literals from django.db import models, migrations from django.conf import settings import django_pgjson.fields import django.utils.timezone import django.db.models.deletion import djorm_pgarray.fields import taiga.projects.history.models class Migration(migrations.Migration): dependencies = [ migrations.swappable_dependency(settings.AUTH_USER_MODEL), ('users', '0002_auto_20140903_0916'), ] operations = [ migrations.CreateModel( name='Membership', fields=[ ('id', models.AutoField(serialize=False, primary_key=True, auto_created=True, verbose_name='ID')), ('is_owner', models.BooleanField(default=False)), ('email', models.EmailField(max_length=255, null=True, default=None, verbose_name='email', blank=True)), ('created_at', models.DateTimeField(default=django.utils.timezone.now, verbose_name='creado el')), ('token', models.CharField(max_length=60, null=True, default=None, verbose_name='token', blank=True)), ('invited_by_id', models.IntegerField(null=True, blank=True)), ], options={ 'ordering': ['project', 'user__full_name', 'user__username', 'user__email', 'email'], 'verbose_name_plural': 'membershipss', 'permissions': (('view_membership', 'Can view membership'),), 'verbose_name': 'membership', }, bases=(models.Model,), ), migrations.CreateModel( name='Project', fields=[ ('id', models.AutoField(serialize=False, primary_key=True, auto_created=True, verbose_name='ID')), ('tags', djorm_pgarray.fields.TextArrayField(dbtype='text', verbose_name='tags')), ('name', models.CharField(max_length=250, unique=True, verbose_name='name')), ('slug', models.SlugField(max_length=250, unique=True, verbose_name='slug', blank=True)), ('description', models.TextField(verbose_name='description')), ('created_date', models.DateTimeField(default=django.utils.timezone.now, verbose_name='created date')), ('modified_date', models.DateTimeField(verbose_name='modified date')), ('total_milestones', models.IntegerField(null=True, default=0, verbose_name='total of milestones', blank=True)), ('total_story_points', models.FloatField(default=0, verbose_name='total story points')), ('is_backlog_activated', models.BooleanField(default=True, verbose_name='active backlog panel')), ('is_kanban_activated', models.BooleanField(default=False, verbose_name='active kanban panel')), ('is_wiki_activated', models.BooleanField(default=True, verbose_name='active wiki panel')), ('is_issues_activated', models.BooleanField(default=True, verbose_name='active issues panel')), ('videoconferences', models.CharField(max_length=250, null=True, choices=[('appear-in', 'AppearIn'), ('talky', 'Talky'), ('jitsi', 'Jitsi')], verbose_name='videoconference system', blank=True)), ('videoconferences_salt', models.CharField(max_length=250, null=True, verbose_name='videoconference room salt', blank=True)), ('anon_permissions', djorm_pgarray.fields.TextArrayField(choices=[('view_project', 'View project'), ('view_milestones', 'View milestones'), ('view_us', 'View user stories'), ('view_tasks', 'View tasks'), ('view_issues', 'View issues'), ('view_wiki_pages', 'View wiki pages'), ('view_wiki_links', 'View wiki links')], dbtype='text', default=[], verbose_name='anonymous permissions')), ('public_permissions', djorm_pgarray.fields.TextArrayField(choices=[('view_project', 'View project'), ('view_milestones', 'View milestones'), ('view_us', 'View user stories'), ('view_issues', 'View issues'), ('vote_issues', 'Vote issues'), ('view_tasks', 'View tasks'), ('view_wiki_pages', 'View wiki pages'), ('view_wiki_links', 'View wiki links'), ('request_membership', 'Request membership'), ('add_us_to_project', 'Add user story to project'), ('add_comments_to_us', 'Add comments to user stories'), ('add_comments_to_task', 'Add comments to tasks'), ('add_issue', 'Add issues'), ('add_comments_issue', 'Add comments to issues'), ('add_wiki_page', 'Add wiki page'), ('modify_wiki_page', 'Modify wiki page'), ('add_wiki_link', 'Add wiki link'), ('modify_wiki_link', 'Modify wiki link')], dbtype='text', default=[], verbose_name='user permissions')), ('is_private', models.BooleanField(default=False, verbose_name='is private')), ('tags_colors', djorm_pgarray.fields.TextArrayField(dbtype='text', dimension=2, default=[], null=False, verbose_name='tags colors')), ], options={ 'ordering': ['name'], 'verbose_name_plural': 'projects', 'permissions': (('view_project', 'Can view project'),), 'verbose_name': 'project', }, bases=(models.Model,), ), migrations.AddField( model_name='project', name='members', field=models.ManyToManyField(to=settings.AUTH_USER_MODEL, related_name='projects', verbose_name='members', through='projects.Membership'), preserve_default=True, ), migrations.AddField( model_name='project', name='owner', field=models.ForeignKey(to=settings.AUTH_USER_MODEL, related_name='owned_projects', verbose_name='owner'), preserve_default=True, ), migrations.AddField( model_name='membership', name='user', field=models.ForeignKey(blank=True, default=None, to=settings.AUTH_USER_MODEL, null=True, related_name='memberships'), preserve_default=True, ), <|fim▁hole|> name='project', field=models.ForeignKey(default=1, to='projects.Project', related_name='memberships'), preserve_default=False, ), migrations.AlterUniqueTogether( name='membership', unique_together=set([('user', 'project')]), ), migrations.AddField( model_name='membership', name='role', field=models.ForeignKey(related_name='memberships', to='users.Role', default=1), preserve_default=False, ), ]<|fim▁end|>
migrations.AddField( model_name='membership',
<|file_name|>policies.py<|end_file_name|><|fim▁begin|>import sys, os, fabric class PiServicePolicies: @staticmethod def is_local(): return (not fabric.api.env.hosts or fabric.api.env.hosts[0] in ['localhost', '127.0.0.1', '::1']) @staticmethod def is_pi(): return os.path.isdir('/home/pi') @staticmethod def check_local_or_exit(): if not PiServicePolicies.is_local(): print "...only callable on localhost!!!" sys.exit(-1) @staticmethod def check_remote_or_exit(): if PiServicePolicies.is_local(): print "...only callable on remote host!!!" sys.exit(-1) def check_installed_or_exit(self): if not PiServicePolicies.installed(self): print "...first you have to install this service! fab pi %s:install" sys.exit(-1) <|fim▁hole|><|fim▁end|>
def installed(self): ret = self.file_exists('__init__.py') if not ret: print self.name+' not installed' return ret
<|file_name|>backend.go<|end_file_name|><|fim▁begin|>package ssh import ( "strings" "sync" "github.com/hashicorp/vault/helper/salt" "github.com/hashicorp/vault/logical" "github.com/hashicorp/vault/logical/framework" ) type backend struct { *framework.Backend view logical.Storage salt *salt.Salt saltMutex sync.RWMutex } func Factory(conf *logical.BackendConfig) (logical.Backend, error) { b, err := Backend(conf) if err != nil { return nil, err } if err := b.Setup(conf); err != nil { return nil, err } return b, nil } func Backend(conf *logical.BackendConfig) (*backend, error) { var b backend b.view = conf.StorageView b.Backend = &framework.Backend{ Help: strings.TrimSpace(backendHelp), PathsSpecial: &logical.Paths{ Unauthenticated: []string{ "verify", "public_key", }, LocalStorage: []string{ "otp/", }, }, Paths: []*framework.Path{ pathConfigZeroAddress(&b), pathKeys(&b), pathListRoles(&b), pathRoles(&b), pathCredsCreate(&b), pathLookup(&b), pathVerify(&b), pathConfigCA(&b), pathSign(&b), pathFetchPublicKey(&b), }, Secrets: []*framework.Secret{ secretDynamicKey(&b), secretOTP(&b), }, Invalidate: b.invalidate, BackendType: logical.TypeLogical, } return &b, nil } func (b *backend) Salt() (*salt.Salt, error) { b.saltMutex.RLock() if b.salt != nil { defer b.saltMutex.RUnlock() return b.salt, nil } b.saltMutex.RUnlock()<|fim▁hole|> b.saltMutex.Lock() defer b.saltMutex.Unlock() if b.salt != nil { return b.salt, nil } salt, err := salt.NewSalt(b.view, &salt.Config{ HashFunc: salt.SHA256Hash, Location: salt.DefaultLocation, }) if err != nil { return nil, err } b.salt = salt return salt, nil } func (b *backend) invalidate(key string) { switch key { case salt.DefaultLocation: b.saltMutex.Lock() defer b.saltMutex.Unlock() b.salt = nil } } const backendHelp = ` The SSH backend generates credentials allowing clients to establish SSH connections to remote hosts. There are three variants of the backend, which generate different types of credentials: dynamic keys, One-Time Passwords (OTPs) and certificate authority. The desired behavior is role-specific and chosen at role creation time with the 'key_type' parameter. Please see the backend documentation for a thorough description of both types. The Vault team strongly recommends the OTP type. After mounting this backend, before generating credentials, configure the backend's lease behavior using the 'config/lease' endpoint and create roles using the 'roles/' endpoint. `<|fim▁end|>
<|file_name|>package.py<|end_file_name|><|fim▁begin|>############################################################################## # Copyright (c) 2013-2017, Lawrence Livermore National Security, LLC. # Produced at the Lawrence Livermore National Laboratory. # # This file is part of Spack. # Created by Todd Gamblin, [email protected], All rights reserved. # LLNL-CODE-647188 # # For details, see https://github.com/spack/spack # Please also see the NOTICE and LICENSE files for our notice and the LGPL. # # This program is free software; you can redistribute it and/or modify # it under the terms of the GNU Lesser General Public License (as # published by the Free Software Foundation) version 2.1, February 1999. # # This program is distributed in the hope that it will be useful, but # WITHOUT ANY WARRANTY; without even the IMPLIED WARRANTY OF # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the terms and # conditions of the GNU Lesser General Public License for more details. # # You should have received a copy of the GNU Lesser General Public # License along with this program; if not, write to the Free Software # Foundation, Inc., 59 Temple Place, Suite 330, Boston, MA 02111-1307 USA ############################################################################## from spack import * class PyFlaskSocketio(PythonPackage): """Flask-SocketIO gives Flask applications access to low latency bi-directional communications between the clients and the server. The client-side application can use any of the SocketIO official clients libraries in Javascript, C++, Java and Swift, or any compatible client to establish a permanent connection to the server. """<|fim▁hole|> version('2.9.6', 'bca83faf38355bd91911f2f140f9b50f') depends_on('py-setuptools', type='build') depends_on('[email protected]:', type=('build', 'run')) depends_on('[email protected]:', type=('build', 'run')) depends_on('py-werkzeug', type=('build', 'run'))<|fim▁end|>
homepage = "https://flask-socketio.readthedocs.io" url = "https://pypi.io/packages/source/F/Flask-SocketIO/Flask-SocketIO-2.9.6.tar.gz"
<|file_name|>tournament.py<|end_file_name|><|fim▁begin|># coding: utf-8 # license: GPLv3 from enemies import * from hero import * def annoying_input_int(message =''): answer = None while answer == None: try: answer = int(input(message)) except ValueError: print('Вы ввели недопустимые символы') return answer def game_tournament(hero, dragon_list): for dragon in dragon_list: print('Вышел', dragon._color, 'дракон!') while dragon.is_alive() and hero.is_alive(): print('Вопрос:', dragon.question()) answer = annoying_input_int('Ответ:') if dragon.check_answer(answer): hero.attack(dragon) print('Верно! \n** дракон кричит от боли **') else: dragon.attack(hero) print('Ошибка! \n** вам нанесён удар... **') if dragon.is_alive(): break print('Дракон', dragon._color, 'повержен!\n') if hero.is_alive(): print('Поздравляем! Вы победили!') print('Ваш накопленный опыт:', hero._experience) else: print('К сожалению, Вы проиграли...') def start_game(): try: print('Добро пожаловать в арифметико-ролевую игру с драконами!') print('Представьтесь, пожалуйста: ', end = '') hero = Hero(input()) dragon_number = 3<|fim▁hole|> assert(len(dragon_list) == 3) print('У Вас на пути', dragon_number, 'драконов!') game_tournament(hero, dragon_list) except EOFError: print('Поток ввода закончился. Извините, принимать ответы более невозможно.')<|fim▁end|>
dragon_list = generate_dragon_list(dragon_number)
<|file_name|>HsqlList.java<|end_file_name|><|fim▁begin|>/* Copyright (c) 2001-2009, The HSQL Development Group * All rights reserved. * * Redistribution and use in source and binary forms, with or without * modification, are permitted provided that the following conditions are met: * * Redistributions of source code must retain the above copyright notice, this * list of conditions and the following disclaimer. * * Redistributions in binary form must reproduce the above copyright notice, * this list of conditions and the following disclaimer in the documentation * and/or other materials provided with the distribution. * * Neither the name of the HSQL Development Group nor the names of its * contributors may be used to endorse or promote products derived from this * software without specific prior written permission. * * THIS SOFTWARE IS PROVIDED BY THE COPYRIGHT HOLDERS AND CONTRIBUTORS "AS IS" * AND ANY EXPRESS OR IMPLIED WARRANTIES, INCLUDING, BUT NOT LIMITED TO, THE * IMPLIED WARRANTIES OF MERCHANTABILITY AND FITNESS FOR A PARTICULAR PURPOSE * ARE DISCLAIMED. IN NO EVENT SHALL HSQL DEVELOPMENT GROUP, HSQLDB.ORG, * OR CONTRIBUTORS BE LIABLE FOR ANY DIRECT, INDIRECT, INCIDENTAL, SPECIAL, * EXEMPLARY, OR CONSEQUENTIAL DAMAGES (INCLUDING, BUT NOT LIMITED TO, * PROCUREMENT OF SUBSTITUTE GOODS OR SERVICES; * LOSS OF USE, DATA, OR PROFITS; OR BUSINESS INTERRUPTION) HOWEVER CAUSED AND * ON ANY THEORY OF LIABILITY, WHETHER IN CONTRACT, STRICT LIABILITY, OR TORT * (INCLUDING NEGLIGENCE OR OTHERWISE) ARISING IN ANY WAY OUT OF THE USE OF THIS * SOFTWARE, EVEN IF ADVISED OF THE POSSIBILITY OF SUCH DAMAGE. */ package org.hsqldb_voltpatches.lib; /**<|fim▁hole|> * This should be used as the datatype for parameters and instance variables * instead of HsqlArrayList or HsqlLinkedList to allow interchangable use of the * two. * * @author dnordahl@users * @version 1.7.2 * @since 1.7.2 */ public interface HsqlList extends Collection { void add(int index, Object element); boolean add(Object element); Object get(int index); Object remove(int index); Object set(int index, Object element); boolean isEmpty(); int size(); Iterator iterator(); }<|fim▁end|>
<|file_name|>testRBTCoM.py<|end_file_name|><|fim▁begin|>from __future__ import print_function import unittest import numpy as np import pydrake import os.path class TestRBTCoM(unittest.TestCase): def testCoM0(self): r = pydrake.rbtree.RigidBodyTree(os.path.join(pydrake.getDrakePath(), "examples/Pendulum/Pendulum.urdf")) kinsol = r.doKinematics(np.zeros((7, 1)), np.zeros((7, 1))) c = r.centerOfMass(kinsol) self.assertTrue(np.allclose(c.flat, [0.0, 0.0, -0.2425], atol=1e-4)) def testCoMJacobian(self): r = pydrake.rbtree.RigidBodyTree(os.path.join(pydrake.getDrakePath(), "examples/Pendulum/Pendulum.urdf")) q = r.getRandomConfiguration() kinsol = r.doKinematics(q, np.zeros((7, 1))) J = r.centerOfMassJacobian(kinsol) self.assertTrue(np.shape(J) == (3, 7)) q = r.getZeroConfiguration() kinsol = r.doKinematics(q, np.zeros((7, 1))) J = r.centerOfMassJacobian(kinsol) self.assertTrue(np.allclose(J.flat, [1., 0., 0., 0., -0.2425, 0., -0.25,<|fim▁hole|> if __name__ == '__main__': unittest.main()<|fim▁end|>
0., 1., 0., 0.2425, 0., 0., 0., 0., 0., 1., 0., 0., 0., 0.], atol=1e-4))
<|file_name|>_colorbar.py<|end_file_name|><|fim▁begin|>import _plotly_utils.basevalidators class ColorbarValidator(_plotly_utils.basevalidators.CompoundValidator): def __init__(self, plotly_name="colorbar", parent_name="bar.marker", **kwargs): super(ColorbarValidator, self).__init__( plotly_name=plotly_name, parent_name=parent_name, data_class_str=kwargs.pop("data_class_str", "ColorBar"), data_docs=kwargs.pop( "data_docs", """ bgcolor Sets the color of padded area. bordercolor Sets the axis line color. borderwidth Sets the width (in px) or the border enclosing this color bar. dtick Sets the step in-between ticks on this axis. Use with `tick0`. Must be a positive number, or special strings available to "log" and "date" axes. If the axis `type` is "log", then ticks are set every 10^(n*dtick) where n is the tick number. For example, to set a tick mark at 1, 10, 100, 1000, ... set dtick to 1. To set tick marks at 1, 100, 10000, ... set dtick to 2. To set tick marks at 1, 5, 25, 125, 625, 3125, ... set dtick to log_10(5), or 0.69897000433. "log" has several special values; "L<f>", where `f` is a positive number, gives ticks linearly spaced in value (but not position). For example `tick0` = 0.1, `dtick` = "L0.5" will put ticks at 0.1, 0.6, 1.1, 1.6 etc. To show powers of 10 plus small digits between, use "D1" (all digits) or "D2" (only 2 and 5). `tick0` is ignored for "D1" and "D2". If the axis `type` is "date", then you must convert the time to milliseconds. For example, to set the interval between ticks to one day, set `dtick` to 86400000.0. "date" also has special values "M<n>" gives ticks spaced by a number of months. `n` must be a positive integer. To set ticks on the 15th of every third month, set `tick0` to "2000-01-15" and `dtick` to "M3". To set ticks every 4 years, set `dtick` to "M48" exponentformat Determines a formatting rule for the tick exponents. For example, consider the number 1,000,000,000. If "none", it appears as 1,000,000,000. If "e", 1e+9. If "E", 1E+9. If "power", 1x10^9 (with 9 in a super script). If "SI", 1G. If "B", 1B. len Sets the length of the color bar This measure excludes the padding of both ends. That is, the color bar length is this length minus the padding on both ends. lenmode Determines whether this color bar's length (i.e. the measure in the color variation direction) is set in units of plot "fraction" or in *pixels. Use `len` to set the value. minexponent Hide SI prefix for 10^n if |n| is below this number. This only has an effect when `tickformat` is "SI" or "B". nticks Specifies the maximum number of ticks for the particular axis. The actual number of ticks will be chosen automatically to be less than or equal to `nticks`. Has an effect only if `tickmode` is set to "auto". orientation Sets the orientation of the colorbar. outlinecolor Sets the axis line color. outlinewidth Sets the width (in px) of the axis line. separatethousands If "true", even 4-digit integers are separated showexponent If "all", all exponents are shown besides their significands. If "first", only the exponent of the first tick is shown. If "last", only the exponent of the last tick is shown. If "none", no exponents appear. showticklabels<|fim▁hole|> If "all", all tick labels are displayed with a prefix. If "first", only the first tick is displayed with a prefix. If "last", only the last tick is displayed with a suffix. If "none", tick prefixes are hidden. showticksuffix Same as `showtickprefix` but for tick suffixes. thickness Sets the thickness of the color bar This measure excludes the size of the padding, ticks and labels. thicknessmode Determines whether this color bar's thickness (i.e. the measure in the constant color direction) is set in units of plot "fraction" or in "pixels". Use `thickness` to set the value. tick0 Sets the placement of the first tick on this axis. Use with `dtick`. If the axis `type` is "log", then you must take the log of your starting tick (e.g. to set the starting tick to 100, set the `tick0` to 2) except when `dtick`=*L<f>* (see `dtick` for more info). If the axis `type` is "date", it should be a date string, like date data. If the axis `type` is "category", it should be a number, using the scale where each category is assigned a serial number from zero in the order it appears. tickangle Sets the angle of the tick labels with respect to the horizontal. For example, a `tickangle` of -90 draws the tick labels vertically. tickcolor Sets the tick color. tickfont Sets the color bar's tick label font tickformat Sets the tick label formatting rule using d3 formatting mini-languages which are very similar to those in Python. For numbers, see: h ttps://github.com/d3/d3-format/tree/v1.4.5#d3-f ormat. And for dates see: https://github.com/d3/d3-time- format/tree/v2.2.3#locale_format. We add two items to d3's date formatter: "%h" for half of the year as a decimal number as well as "%{n}f" for fractional seconds with n digits. For example, *2016-10-13 09:15:23.456* with tickformat "%H~%M~%S.%2f" would display "09~15~23.46" tickformatstops A tuple of :class:`plotly.graph_objects.bar.mar ker.colorbar.Tickformatstop` instances or dicts with compatible properties tickformatstopdefaults When used in a template (as layout.template.dat a.bar.marker.colorbar.tickformatstopdefaults), sets the default property values to use for elements of bar.marker.colorbar.tickformatstops ticklabeloverflow Determines how we handle tick labels that would overflow either the graph div or the domain of the axis. The default value for inside tick labels is *hide past domain*. In other cases the default is *hide past div*. ticklabelposition Determines where tick labels are drawn relative to the ticks. Left and right options are used when `orientation` is "h", top and bottom when `orientation` is "v". ticklabelstep Sets the spacing between tick labels as compared to the spacing between ticks. A value of 1 (default) means each tick gets a label. A value of 2 means shows every 2nd label. A larger value n means only every nth tick is labeled. `tick0` determines which labels are shown. Not implemented for axes with `type` "log" or "multicategory", or when `tickmode` is "array". ticklen Sets the tick length (in px). tickmode Sets the tick mode for this axis. If "auto", the number of ticks is set via `nticks`. If "linear", the placement of the ticks is determined by a starting position `tick0` and a tick step `dtick` ("linear" is the default value if `tick0` and `dtick` are provided). If "array", the placement of the ticks is set via `tickvals` and the tick text is `ticktext`. ("array" is the default value if `tickvals` is provided). tickprefix Sets a tick label prefix. ticks Determines whether ticks are drawn or not. If "", this axis' ticks are not drawn. If "outside" ("inside"), this axis' are drawn outside (inside) the axis lines. ticksuffix Sets a tick label suffix. ticktext Sets the text displayed at the ticks position via `tickvals`. Only has an effect if `tickmode` is set to "array". Used with `tickvals`. ticktextsrc Sets the source reference on Chart Studio Cloud for `ticktext`. tickvals Sets the values at which ticks on this axis appear. Only has an effect if `tickmode` is set to "array". Used with `ticktext`. tickvalssrc Sets the source reference on Chart Studio Cloud for `tickvals`. tickwidth Sets the tick width (in px). title :class:`plotly.graph_objects.bar.marker.colorba r.Title` instance or dict with compatible properties titlefont Deprecated: Please use bar.marker.colorbar.title.font instead. Sets this color bar's title font. Note that the title's font used to be set by the now deprecated `titlefont` attribute. titleside Deprecated: Please use bar.marker.colorbar.title.side instead. Determines the location of color bar's title with respect to the color bar. Defaults to "top" when `orientation` if "v" and defaults to "right" when `orientation` if "h". Note that the title's location used to be set by the now deprecated `titleside` attribute. x Sets the x position of the color bar (in plot fraction). Defaults to 1.02 when `orientation` is "v" and 0.5 when `orientation` is "h". xanchor Sets this color bar's horizontal position anchor. This anchor binds the `x` position to the "left", "center" or "right" of the color bar. Defaults to "left" when `orientation` is "v" and "center" when `orientation` is "h". xpad Sets the amount of padding (in px) along the x direction. y Sets the y position of the color bar (in plot fraction). Defaults to 0.5 when `orientation` is "v" and 1.02 when `orientation` is "h". yanchor Sets this color bar's vertical position anchor This anchor binds the `y` position to the "top", "middle" or "bottom" of the color bar. Defaults to "middle" when `orientation` is "v" and "bottom" when `orientation` is "h". ypad Sets the amount of padding (in px) along the y direction. """, ), **kwargs )<|fim▁end|>
Determines whether or not the tick labels are drawn. showtickprefix
<|file_name|>crash28.C<|end_file_name|><|fim▁begin|>// Build don't link: // Origin: Jakub Jelinek <[email protected]> namespace N { class X; template <class T> class Y { public: inline Y () {} inline operator const Y<X> & () const { return *reinterpret_cast<const Y<X> *>(this);<|fim▁hole|>{ public: inline bar () {} inline bar (const ::N::Y< ::N::X>& a); }; class foo { bool b; public: foo(); void x () throw(bar); }; void foo::x() throw(bar) { if (!b) throw bar (static_cast<::N::X*>(this)); // ERROR - parse error }<|fim▁end|>
} }; } class bar
<|file_name|>arg.rs<|end_file_name|><|fim▁begin|>extern crate ttml; use ttml::arg::TokenArg; #[test] fn token_arg_to_string() { let token = TokenArg { name: "test".to_string(), attribute: Some("test_attr".to_string()), macro_name: None, };<|fim▁hole|> let token = TokenArg { name: "test".to_string(), attribute: None, macro_name: Some("macro_name".to_string()), }; assert_eq!(token.to_string(), "@test->macro_name".to_string()); let token = TokenArg { name: "test_token".to_string(), attribute: None, macro_name: None, }; assert_eq!(token.to_string(), "@test_token".to_string()); }<|fim▁end|>
assert_eq!(token.to_string(), "@test.test_attr".to_string());
<|file_name|>subplot.py<|end_file_name|><|fim▁begin|>""" subplot - Manage modern mode figure subplot configuration and selection. """ import contextlib from pygmt.clib import Session from pygmt.exceptions import GMTInvalidInput from pygmt.helpers import ( build_arg_string, fmt_docstring, is_nonstr_iter, kwargs_to_strings, use_alias, ) @fmt_docstring @contextlib.contextmanager @use_alias( Ff="figsize", Fs="subsize", A="autolabel", B="frame", C="clearance", J="projection", M="margins", R="region", SC="sharex", SR="sharey", T="title", V="verbose", X="xshift", Y="yshift", ) @kwargs_to_strings(Ff="sequence", Fs="sequence", M="sequence", R="sequence") def subplot(self, nrows=1, ncols=1, **kwargs): r""" Create multi-panel subplot figures. This function is used to split the current figure into a rectangular layout of subplots that each may contain a single self-contained figure. Begin by defining the layout of the entire multi-panel illustration. Several parameters are available to specify the systematic layout, labeling, dimensions, and more for the subplots. Full option list at :gmt-docs:`subplot.html#synopsis-begin-mode` {aliases} Parameters ---------- nrows : int Number of vertical rows of the subplot grid. ncols : int Number of horizontal columns of the subplot grid. figsize : tuple Specify the final figure dimensions as (*width*, *height*). subsize : tuple Specify the dimensions of each subplot directly as (*width*, *height*). Note that only one of ``figsize`` or ``subsize`` can be provided at once. autolabel : bool or str [*autolabel*][**+c**\ *dx*\ [/*dy*]][**+g**\ *fill*][**+j**\|\ **J**\ *refpoint*][**+o**\ *dx*\ [/*dy*]][**+p**\ *pen*][**+r**\|\ **R**] [**+v**]. Specify automatic tagging of each subplot. Append either a number or letter [a]. This sets the tag of the first, top-left subplot and others follow sequentially. Surround the number or letter by parentheses on any side if these should be typeset as part of the tag. Use **+j**\|\ **J**\ *refpoint* to specify where the tag should be placed in the subplot [TL]. Note: **+j** sets the justification of the tag to *refpoint* (suitable for interior tags) while **+J** instead selects the mirror opposite (suitable for exterior tags). Append **+c**\ *dx*\[/*dy*] to set the clearance between the tag and a surrounding text box requested via **+g** or **+p** [3p/3p, i.e., 15% of the :gmt-term:`FONT_TAG` size dimension]. Append **+g**\ *fill* to paint the tag's text box with *fill* [no painting]. Append **+o**\ *dx*\ [/*dy*] to offset the tag's reference point in the direction implied by the justification [4p/4p, i.e., 20% of the :gmt-term:`FONT_TAG` size]. Append **+p**\ *pen* to draw the outline of the tag's text box using selected *pen* [no outline]. Append **+r** to typeset your tag numbers using lowercase Roman numerals; use **+R** for uppercase Roman numerals [Arabic numerals]. Append **+v** to increase tag numbers vertically down columns [horizontally across rows]. {B} clearance : str or list [*side*]\ *clearance*. Reserve a space of dimension *clearance* between the margin and the subplot on the specified side, using *side* values from **w**, **e**, **s**, or **n**; or **x** for both **w** and **e**; or **y** for both **s** and **n**. No *side* means all sides (i.e. ``clearance='1c'`` would set a clearance of 1 cm on all sides). The option is repeatable to set aside space on more than one side (e.g. ``clearance=['w1c', 's2c']`` would set a clearance of 1 cm on west side and 2 cm on south side). Such space will be left untouched by the main map plotting but can be accessed by modules that plot scales, bars, text, etc. {J} margins : str or list This is margin space that is added between neighboring subplots (i.e., the interior margins) in addition to the automatic space added for tick marks, annotations, and labels. The margins can be specified as either: - a single value (for same margin on all sides). E.g. '5c'. - a pair of values (for setting separate horizontal and vertical margins). E.g. ['5c', '3c']. - a set of four values (for setting separate left, right, bottom, and top margins). E.g. ['1c', '2c', '3c', '4c']. The actual gap created is always a sum of the margins for the two opposing sides (e.g., east plus west or south plus north margins) [Default is half the primary annotation font size, giving the full annotation font size as the default gap]. {R} sharex : bool or str Set subplot layout for shared x-axes. Use when all subplots in a column share a common *x*-range. If ``sharex=True``, the first (i.e., **t**\ op) and the last (i.e., **b**\ ottom) rows will have *x*-annotations; use ``sharex='t'`` or ``sharex='b'`` to select only one of those two rows [both]. Append **+l** if annotated *x*-axes should have a label [none]; optionally append the label if it is the same for the entire subplot. Append **+t** to make space for subplot titles for each row; use **+tc** for top row titles only [no subplot titles]. sharey : bool or str Set subplot layout for shared y-axes. Use when all subplots in a row share a common *y*-range. If ``sharey=True``, the first (i.e., **l**\ eft) and the last (i.e., **r**\ ight) columns will have *y*-annotations; use ``sharey='l'`` or ``sharey='r'`` to select only one of those two columns [both]. Append **+l** if annotated *y*-axes will have a label [none]; optionally, append the label if it is the same for the entire subplot. Append **+p** to make all annotations axis-parallel [horizontal]; if not used you may have to set ``clearance`` to secure extra space for long horizontal annotations. Notes for ``sharex``/``sharey``: - Labels and titles that depends on which row or column are specified as usual via a subplot's own ``frame`` setting. - Append **+w** to the ``figsize`` or ``subsize`` parameter to draw horizontal and vertical lines between interior panels using selected pen [no lines]. title : str While individual subplots can have titles (see ``sharex``/``sharey`` or ``frame``), the entire figure may also have an overarching *heading* [no heading]. Font is determined by setting :gmt-term:`FONT_HEADING`. {V} {XY} """ kwargs = self._preprocess(**kwargs) # pylint: disable=protected-access # allow for spaces in string without needing double quotes if isinstance(kwargs.get("A"), str): kwargs["A"] = f'"{kwargs.get("A")}"' kwargs["T"] = f'"{kwargs.get("T")}"' if kwargs.get("T") else None if nrows < 1 or ncols < 1: raise GMTInvalidInput("Please ensure that both 'nrows'>=1 and 'ncols'>=1.") if kwargs.get("Ff") and kwargs.get("Fs"): raise GMTInvalidInput( "Please provide either one of 'figsize' or 'subsize' only." ) with Session() as lib: try: arg_str = " ".join(["begin", f"{nrows}x{ncols}", build_arg_string(kwargs)]) lib.call_module("subplot", arg_str) yield finally: v_arg = build_arg_string({"V": kwargs.get("V")}) lib.call_module("subplot", f"end {v_arg}") @fmt_docstring @contextlib.contextmanager @use_alias(A="fixedlabel", C="clearance", V="verbose") def set_panel(self, panel=None, **kwargs): r""" Set the current subplot panel to plot on. Before you start plotting you must first select the active subplot. Note: If any *projection* option is passed with the question mark **?** as scale or width when plotting subplots, then the dimensions of the map are automatically determined by the subplot size and your region. For Cartesian plots: If you want the scale to apply equally to both dimensions then you must specify ``projection="x"`` [The default ``projection="X"`` will fill the subplot by using unequal scales]. {aliases} Parameters ---------- panel : str or list *row,col*\|\ *index*. Sets the current subplot until further notice. **Note**: First *row* or *col* is 0, not 1. If not given we go to the next subplot by order specified via ``autolabel`` in :meth:`pygmt.Figure.subplot`. As an alternative, you may bypass using :meth:`pygmt.Figure.set_panel` and instead supply the common option **panel**\ =[*row,col*] to the first plot command you issue in that subplot. GMT maintains information about the current figure and subplot. Also, you may give the one-dimensional *index* instead which starts at 0 and follows the row or column order set via ``autolabel`` in :meth:`pygmt.Figure.subplot`. fixedlabel : str Overrides the automatic labeling with the given string. No modifiers are allowed. Placement, justification, etc. are all inherited from how ``autolabel`` was specified by the initial :meth:`pygmt.Figure.subplot` command. clearance : str or list [*side*]\ *clearance*. Reserve a space of dimension *clearance* between the margin and the subplot on the specified side, using *side* values from **w**, **e**, **s**, or **n**. The option is repeatable to set aside space on more than one side (e.g. ``clearance=['w1c', 's2c']`` would set a clearance of 1 cm on west side and 2 cm on south side). Such space will be left untouched by the main map plotting but can be accessed by modules that plot scales, bars, text, etc. This setting overrides the common clearances set by ``clearance`` in the initial :meth:`pygmt.Figure.subplot` call. {V} """ kwargs = self._preprocess(**kwargs) # pylint: disable=protected-access # allow for spaces in string with needing double quotes kwargs["A"] = f'"{kwargs.get("A")}"' if kwargs.get("A") is not None else None # convert tuple or list to comma-separated str panel = ",".join(map(str, panel)) if is_nonstr_iter(panel) else panel with Session() as lib: arg_str = " ".join(["set", f"{panel}", build_arg_string(kwargs)]) lib.call_module(module="subplot", args=arg_str)<|fim▁hole|><|fim▁end|>
yield
<|file_name|>http_loader.rs<|end_file_name|><|fim▁begin|>/* This Source Code Form is subject to the terms of the Mozilla Public * License, v. 2.0. If a copy of the MPL was not distributed with this * file, You can obtain one at http://mozilla.org/MPL/2.0/. */ use brotli::Decompressor; use connector::{Connector, create_http_connector}; use content_blocker_parser::RuleList; use cookie; use cookie_storage::CookieStorage; use devtools_traits::{ChromeToDevtoolsControlMsg, DevtoolsControlMsg, HttpRequest as DevtoolsHttpRequest}; use devtools_traits::{HttpResponse as DevtoolsHttpResponse, NetworkEvent}; use fetch::cors_cache::CorsCache; use fetch::methods::{Data, DoneChannel, FetchContext, Target, is_simple_header, is_simple_method, main_fetch}; use flate2::read::{DeflateDecoder, GzDecoder}; use hsts::HstsList; use hyper::Error as HttpError; use hyper::LanguageTag; use hyper::client::{Pool, Request as HyperRequest, Response as HyperResponse}; use hyper::header::{AcceptEncoding, AcceptLanguage, AccessControlAllowCredentials}; use hyper::header::{AccessControlAllowOrigin, AccessControlAllowHeaders, AccessControlAllowMethods}; use hyper::header::{AccessControlRequestHeaders, AccessControlMaxAge, AccessControlRequestMethod}; use hyper::header::{Authorization, Basic, CacheControl, CacheDirective, ContentEncoding}; use hyper::header::{ContentLength, Encoding, Header, Headers, Host, IfMatch, IfRange}; use hyper::header::{IfUnmodifiedSince, IfModifiedSince, IfNoneMatch, Location, Pragma, Quality}; use hyper::header::{QualityItem, Referer, SetCookie, UserAgent, qitem}; use hyper::method::Method; use hyper::net::Fresh; use hyper::status::StatusCode; use hyper_serde::Serde; use log; use msg::constellation_msg::PipelineId; use net_traits::{CookieSource, FetchMetadata, NetworkError, ReferrerPolicy}; use net_traits::hosts::replace_hosts; use net_traits::request::{CacheMode, CredentialsMode, Destination, Origin}; use net_traits::request::{RedirectMode, Referrer, Request, RequestMode, ResponseTainting}; use net_traits::response::{HttpsState, Response, ResponseBody, ResponseType}; use openssl; use openssl::ssl::error::{OpensslError, SslError}; use resource_thread::AuthCache; use servo_url::ServoUrl; use std::collections::HashSet; use std::error::Error; use std::io::{self, Read, Write}; use std::iter::FromIterator; use std::mem; use std::ops::Deref; use std::rc::Rc; use std::sync::{Arc, RwLock}; use std::sync::mpsc::{channel, Sender}; use std::thread; use time; use time::Tm; use unicase::UniCase; use url::Origin as UrlOrigin; use uuid; fn read_block<R: Read>(reader: &mut R) -> Result<Data, ()> { let mut buf = vec![0; 1024]; match reader.read(&mut buf) { Ok(len) if len > 0 => { buf.truncate(len); Ok(Data::Payload(buf)) } Ok(_) => Ok(Data::Done), Err(_) => Err(()), } } pub struct HttpState { pub hsts_list: Arc<RwLock<HstsList>>, pub cookie_jar: Arc<RwLock<CookieStorage>>, pub auth_cache: Arc<RwLock<AuthCache>>, pub blocked_content: Arc<Option<RuleList>>, pub connector_pool: Arc<Pool<Connector>>, } impl HttpState { pub fn new(certificate_path: &str) -> HttpState { HttpState { hsts_list: Arc::new(RwLock::new(HstsList::new())), cookie_jar: Arc::new(RwLock::new(CookieStorage::new(150))), auth_cache: Arc::new(RwLock::new(AuthCache::new())), blocked_content: Arc::new(None), connector_pool: create_http_connector(certificate_path), } } } fn precise_time_ms() -> u64 { time::precise_time_ns() / (1000 * 1000) } pub struct WrappedHttpResponse { pub response: HyperResponse } impl Read for WrappedHttpResponse { #[inline] fn read(&mut self, buf: &mut [u8]) -> io::Result<usize> { self.response.read(buf) } } impl WrappedHttpResponse { fn headers(&self) -> &Headers { &self.response.headers } fn content_encoding(&self) -> Option<Encoding> { let encodings = match self.headers().get::<ContentEncoding>() { Some(&ContentEncoding(ref encodings)) => encodings, None => return None, }; if encodings.contains(&Encoding::Gzip) { Some(Encoding::Gzip) } else if encodings.contains(&Encoding::Deflate) { Some(Encoding::Deflate) } else if encodings.contains(&Encoding::EncodingExt("br".to_owned())) { Some(Encoding::EncodingExt("br".to_owned())) } else { None } } } struct NetworkHttpRequestFactory { pub connector: Arc<Pool<Connector>>, } impl NetworkHttpRequestFactory { fn create(&self, url: ServoUrl, method: Method, headers: Headers) -> Result<HyperRequest<Fresh>, NetworkError> { let connection = HyperRequest::with_connector(method, url.clone().into_url().unwrap(), &*self.connector); if let Err(HttpError::Ssl(ref error)) = connection { let error: &(Error + Send + 'static) = &**error; if let Some(&SslError::OpenSslErrors(ref errors)) = error.downcast_ref::<SslError>() { if errors.iter().any(is_cert_verify_error) { let mut error_report = vec![format!("ssl error ({}):", openssl::version::version())]; let mut suggestion = None; for err in errors { if is_unknown_message_digest_err(err) { suggestion = Some("<b>Servo recommends upgrading to a newer OpenSSL version.</b>"); } error_report.push(format_ssl_error(err)); } if let Some(suggestion) = suggestion { error_report.push(suggestion.to_owned()); } let error_report = error_report.join("<br>\n"); return Err(NetworkError::SslValidation(url, error_report)); } } } let mut request = match connection { Ok(req) => req, Err(e) => return Err(NetworkError::Internal(e.description().to_owned())), }; *request.headers_mut() = headers; Ok(request) } } fn set_default_accept_encoding(headers: &mut Headers) { if headers.has::<AcceptEncoding>() { return } headers.set(AcceptEncoding(vec![ qitem(Encoding::Gzip), qitem(Encoding::Deflate), qitem(Encoding::EncodingExt("br".to_owned())) ])); } pub fn set_default_accept_language(headers: &mut Headers) { if headers.has::<AcceptLanguage>() { return; } let mut en_us: LanguageTag = Default::default(); en_us.language = Some("en".to_owned()); en_us.region = Some("US".to_owned()); let mut en: LanguageTag = Default::default(); en.language = Some("en".to_owned()); headers.set(AcceptLanguage(vec![ qitem(en_us), QualityItem::new(en, Quality(500)), ])); } /// https://w3c.github.io/webappsec-referrer-policy/#referrer-policy-state-no-referrer-when-downgrade fn no_referrer_when_downgrade_header(referrer_url: ServoUrl, url: ServoUrl) -> Option<ServoUrl> { if referrer_url.scheme() == "https" && url.scheme() != "https" { return None; } return strip_url(referrer_url, false); } /// https://w3c.github.io/webappsec-referrer-policy/#referrer-policy-strict-origin fn strict_origin(referrer_url: ServoUrl, url: ServoUrl) -> Option<ServoUrl> { if referrer_url.scheme() == "https" && url.scheme() != "https" { return None; } strip_url(referrer_url, true) } /// https://w3c.github.io/webappsec-referrer-policy/#referrer-policy-strict-origin-when-cross-origin fn strict_origin_when_cross_origin(referrer_url: ServoUrl, url: ServoUrl) -> Option<ServoUrl> { if referrer_url.scheme() == "https" && url.scheme() != "https" { return None; } let cross_origin = referrer_url.origin() != url.origin(); strip_url(referrer_url, cross_origin) } /// https://w3c.github.io/webappsec-referrer-policy/#strip-url fn strip_url(mut referrer_url: ServoUrl, origin_only: bool) -> Option<ServoUrl> { if referrer_url.scheme() == "https" || referrer_url.scheme() == "http" { { let referrer = referrer_url.as_mut_url().unwrap(); referrer.set_username("").unwrap(); referrer.set_password(None).unwrap(); referrer.set_fragment(None); if origin_only { referrer.set_path(""); referrer.set_query(None); } } return Some(referrer_url); } return None; } /// https://w3c.github.io/webappsec-referrer-policy/#determine-requests-referrer /// Steps 4-6. pub fn determine_request_referrer(headers: &mut Headers, referrer_policy: ReferrerPolicy, referrer_source: ServoUrl, current_url: ServoUrl) -> Option<ServoUrl> { assert!(!headers.has::<Referer>()); // FIXME(#14505): this does not seem to be the correct way of checking for // same-origin requests. let cross_origin = referrer_source.origin() != current_url.origin(); // FIXME(#14506): some of these cases are expected to consider whether the // request's client is "TLS-protected", whatever that means. match referrer_policy { ReferrerPolicy::NoReferrer => None, ReferrerPolicy::Origin => strip_url(referrer_source, true), ReferrerPolicy::SameOrigin => if cross_origin { None } else { strip_url(referrer_source, false) }, ReferrerPolicy::UnsafeUrl => strip_url(referrer_source, false), ReferrerPolicy::OriginWhenCrossOrigin => strip_url(referrer_source, cross_origin), ReferrerPolicy::StrictOrigin => strict_origin(referrer_source, current_url), ReferrerPolicy::StrictOriginWhenCrossOrigin => strict_origin_when_cross_origin(referrer_source, current_url), ReferrerPolicy::NoReferrerWhenDowngrade => no_referrer_when_downgrade_header(referrer_source, current_url), } } pub fn set_request_cookies(url: &ServoUrl, headers: &mut Headers, cookie_jar: &Arc<RwLock<CookieStorage>>) { let mut cookie_jar = cookie_jar.write().unwrap(); if let Some(cookie_list) = cookie_jar.cookies_for_url(url, CookieSource::HTTP) { let mut v = Vec::new(); v.push(cookie_list.into_bytes()); headers.set_raw("Cookie".to_owned(), v); } } fn set_cookie_for_url(cookie_jar: &Arc<RwLock<CookieStorage>>, request: &ServoUrl, cookie_val: String) { let mut cookie_jar = cookie_jar.write().unwrap(); let source = CookieSource::HTTP; let header = Header::parse_header(&[cookie_val.into_bytes()]); if let Ok(SetCookie(cookies)) = header { for bare_cookie in cookies { if let Some(cookie) = cookie::Cookie::new_wrapped(bare_cookie, request, source) { cookie_jar.push(cookie, request, source); } } } } fn set_cookies_from_headers(url: &ServoUrl, headers: &Headers, cookie_jar: &Arc<RwLock<CookieStorage>>) { if let Some(cookies) = headers.get_raw("set-cookie") { for cookie in cookies.iter() { if let Ok(cookie_value) = String::from_utf8(cookie.clone()) { set_cookie_for_url(&cookie_jar, &url, cookie_value); } } } } struct StreamedResponse { decoder: Decoder, } impl Read for StreamedResponse { #[inline] fn read(&mut self, buf: &mut [u8]) -> io::Result<usize> { match self.decoder { Decoder::Gzip(ref mut d) => d.read(buf), Decoder::Deflate(ref mut d) => d.read(buf), Decoder::Brotli(ref mut d) => d.read(buf), Decoder::Plain(ref mut d) => d.read(buf) } } } impl StreamedResponse { fn from_http_response(response: WrappedHttpResponse) -> io::Result<StreamedResponse> { let decoder = match response.content_encoding() { Some(Encoding::Gzip) => { Decoder::Gzip(try!(GzDecoder::new(response))) } Some(Encoding::Deflate) => { Decoder::Deflate(DeflateDecoder::new(response)) } Some(Encoding::EncodingExt(ref ext)) if ext == "br" => { Decoder::Brotli(Decompressor::new(response, 1024)) } _ => { Decoder::Plain(response) } }; Ok(StreamedResponse { decoder: decoder }) } } enum Decoder { Gzip(GzDecoder<WrappedHttpResponse>), Deflate(DeflateDecoder<WrappedHttpResponse>), Brotli(Decompressor<WrappedHttpResponse>), Plain(WrappedHttpResponse) } fn prepare_devtools_request(request_id: String, url: ServoUrl, method: Method, headers: Headers, body: Option<Vec<u8>>, pipeline_id: PipelineId, now: Tm, connect_time: u64, send_time: u64, is_xhr: bool) -> ChromeToDevtoolsControlMsg { let request = DevtoolsHttpRequest { url: url, method: method, headers: headers, body: body, pipeline_id: pipeline_id, startedDateTime: now, timeStamp: now.to_timespec().sec, connect_time: connect_time, send_time: send_time, is_xhr: is_xhr, }; let net_event = NetworkEvent::HttpRequest(request); ChromeToDevtoolsControlMsg::NetworkEvent(request_id, net_event) } fn send_request_to_devtools(msg: ChromeToDevtoolsControlMsg, devtools_chan: &Sender<DevtoolsControlMsg>) { devtools_chan.send(DevtoolsControlMsg::FromChrome(msg)).unwrap(); } fn send_response_to_devtools(devtools_chan: &Sender<DevtoolsControlMsg>, request_id: String, headers: Option<Headers>, status: Option<(u16, Vec<u8>)>, pipeline_id: PipelineId) { let response = DevtoolsHttpResponse { headers: headers, status: status, body: None, pipeline_id: pipeline_id }; let net_event_response = NetworkEvent::HttpResponse(response); let msg = ChromeToDevtoolsControlMsg::NetworkEvent(request_id, net_event_response); let _ = devtools_chan.send(DevtoolsControlMsg::FromChrome(msg)); } fn auth_from_cache(auth_cache: &Arc<RwLock<AuthCache>>, origin: &UrlOrigin) -> Option<Basic> { if let Some(ref auth_entry) = auth_cache.read().unwrap().entries.get(&origin.ascii_serialization()) { let user_name = auth_entry.user_name.clone(); let password = Some(auth_entry.password.clone()); Some(Basic { username: user_name, password: password }) } else { None } } fn obtain_response(request_factory: &NetworkHttpRequestFactory, url: &ServoUrl, method: &Method, request_headers: &Headers, data: &Option<Vec<u8>>, load_data_method: &Method, pipeline_id: &Option<PipelineId>, iters: u32, request_id: Option<&str>, is_xhr: bool) -> Result<(WrappedHttpResponse, Option<ChromeToDevtoolsControlMsg>), NetworkError> { let null_data = None; let connection_url = replace_hosts(&url); // loop trying connections in connection pool // they may have grown stale (disconnected), in which case we'll get // a ConnectionAborted error. this loop tries again with a new // connection. loop { let mut headers = request_headers.clone(); // Avoid automatically sending request body if a redirect has occurred. // // TODO - This is the wrong behaviour according to the RFC. However, I'm not // sure how much "correctness" vs. real-world is important in this case. // // https://tools.ietf.org/html/rfc7231#section-6.4 let is_redirected_request = iters != 1; let request_body; match data { &Some(ref d) if !is_redirected_request => { headers.set(ContentLength(d.len() as u64)); request_body = data; } _ => { if *load_data_method != Method::Get && *load_data_method != Method::Head { headers.set(ContentLength(0)) } request_body = &null_data; } } if log_enabled!(log::LogLevel::Info) { info!("{} {}", method, connection_url); for header in headers.iter() { info!(" - {}", header); } info!("{:?}", data); } let connect_start = precise_time_ms(); let request = try!(request_factory.create(connection_url.clone(), method.clone(), headers.clone())); let connect_end = precise_time_ms(); let send_start = precise_time_ms(); let mut request_writer = match request.start() { Ok(streaming) => streaming, Err(e) => return Err(NetworkError::Internal(e.description().to_owned())), }; if let Some(ref data) = *request_body { if let Err(e) = request_writer.write_all(&data) { return Err(NetworkError::Internal(e.description().to_owned())) } } let response = match request_writer.send() { Ok(w) => w, Err(HttpError::Io(ref io_error)) if io_error.kind() == io::ErrorKind::ConnectionAborted => { debug!("connection aborted ({:?}), possibly stale, trying new connection", io_error.description()); continue; }, Err(e) => return Err(NetworkError::Internal(e.description().to_owned())), }; let send_end = precise_time_ms(); let msg = if let Some(request_id) = request_id { if let Some(pipeline_id) = *pipeline_id { Some(prepare_devtools_request( request_id.into(), url.clone(), method.clone(), headers, request_body.clone(), pipeline_id, time::now(), connect_end - connect_start, send_end - send_start, is_xhr)) } else { debug!("Not notifying devtools (no pipeline_id)"); None } } else { debug!("Not notifying devtools (no request_id)"); None }; return Ok((WrappedHttpResponse { response: response }, msg)); } } // FIXME: This incredibly hacky. Make it more robust, and at least test it. fn is_cert_verify_error(error: &OpensslError) -> bool { match error { &OpensslError::UnknownError { ref library, ref function, ref reason } => { library == "SSL routines" && function.to_uppercase() == "SSL3_GET_SERVER_CERTIFICATE" && reason == "certificate verify failed" } } } fn is_unknown_message_digest_err(error: &OpensslError) -> bool { match error { &OpensslError::UnknownError { ref library, ref function, ref reason } => { library == "asn1 encoding routines" && function == "ASN1_item_verify" && reason == "unknown message digest algorithm" } } } fn format_ssl_error(error: &OpensslError) -> String { match error { &OpensslError::UnknownError { ref library, ref function, ref reason } => { format!("{}: {} - {}", library, function, reason) } } } /// [HTTP fetch](https://fetch.spec.whatwg.org#http-fetch) pub fn http_fetch(request: Rc<Request>, cache: &mut CorsCache, cors_flag: bool, cors_preflight_flag: bool, authentication_fetch_flag: bool, target: Target, done_chan: &mut DoneChannel, context: &FetchContext) -> Response { // This is a new async fetch, reset the channel we are waiting on *done_chan = None; // Step 1 let mut response: Option<Response> = None; // Step 2 // nothing to do, since actual_response is a function on response // Step 3 if !request.skip_service_worker.get() && !request.is_service_worker_global_scope { // Substep 1 // TODO (handle fetch unimplemented) if let Some(ref res) = response { // Substep 2 // nothing to do, since actual_response is a function on response // Substep 3 if (res.response_type == ResponseType::Opaque && request.mode != RequestMode::NoCors) || (res.response_type == ResponseType::OpaqueRedirect && request.redirect_mode.get() != RedirectMode::Manual) || (res.url_list.borrow().len() > 1 && request.redirect_mode.get() != RedirectMode::Follow) || res.is_network_error() { return Response::network_error(NetworkError::Internal("Request failed".into())); } // Substep 4 // TODO: set response's CSP list on actual_response } } // Step 4 let credentials = match request.credentials_mode { CredentialsMode::Include => true, CredentialsMode::CredentialsSameOrigin if request.response_tainting.get() == ResponseTainting::Basic => true, _ => false }; // Step 5 if response.is_none() { // Substep 1 if cors_preflight_flag { let method_cache_match = cache.match_method(&*request, request.method.borrow().clone()); let method_mismatch = !method_cache_match && (!is_simple_method(&request.method.borrow()) || request.use_cors_preflight); let header_mismatch = request.headers.borrow().iter().any(|view| !cache.match_header(&*request, view.name()) && !is_simple_header(&view) ); // Sub-substep 1 if method_mismatch || header_mismatch { let preflight_result = cors_preflight_fetch(request.clone(), cache, context); // Sub-substep 2 if let Some(e) = preflight_result.get_network_error() { return Response::network_error(e.clone()); } } } // Substep 2 request.skip_service_worker.set(true); // Substep 3 let fetch_result = http_network_or_cache_fetch(request.clone(), credentials, authentication_fetch_flag, done_chan, context); // Substep 4 if cors_flag && cors_check(request.clone(), &fetch_result).is_err() { return Response::network_error(NetworkError::Internal("CORS check failed".into())); } fetch_result.return_internal.set(false); response = Some(fetch_result); } // response is guaranteed to be something by now let mut response = response.unwrap(); // Step 5 match response.actual_response().status { // Code 301, 302, 303, 307, 308 Some(StatusCode::MovedPermanently) | Some(StatusCode::Found) | Some(StatusCode::SeeOther) | Some(StatusCode::TemporaryRedirect) | Some(StatusCode::PermanentRedirect) => { response = match request.redirect_mode.get() { RedirectMode::Error => Response::network_error(NetworkError::Internal("Redirect mode error".into())), RedirectMode::Manual => { response.to_filtered(ResponseType::OpaqueRedirect) }, RedirectMode::Follow => { // set back to default response.return_internal.set(true); http_redirect_fetch(request, cache, response, cors_flag, target, done_chan, context) } } }, // Code 401 Some(StatusCode::Unauthorized) => { // Step 1 // FIXME: Figure out what to do with request window objects if cors_flag || !credentials { return response; } // Step 2 // TODO: Spec says requires testing on multiple WWW-Authenticate headers // Step 3 if !request.use_url_credentials || authentication_fetch_flag { // TODO: Prompt the user for username and password from the window // Wrong, but will have to do until we are able to prompt the user // otherwise this creates an infinite loop // We basically pretend that the user declined to enter credentials return response; } // Step 4 return http_fetch(request, cache, cors_flag, cors_preflight_flag, true, target, done_chan, context); } // Code 407 Some(StatusCode::ProxyAuthenticationRequired) => { // Step 1 // TODO: Figure out what to do with request window objects <|fim▁hole|> // Step 3 // TODO: Prompt the user for proxy authentication credentials // Wrong, but will have to do until we are able to prompt the user // otherwise this creates an infinite loop // We basically pretend that the user declined to enter credentials return response; // Step 4 // return http_fetch(request, cache, // cors_flag, cors_preflight_flag, // authentication_fetch_flag, target, // done_chan, context); } _ => { } } // Step 6 if authentication_fetch_flag { // TODO: Create authentication entry for this request } // set back to default response.return_internal.set(true); // Step 7 response } /// [HTTP redirect fetch](https://fetch.spec.whatwg.org#http-redirect-fetch) fn http_redirect_fetch(request: Rc<Request>, cache: &mut CorsCache, response: Response, cors_flag: bool, target: Target, done_chan: &mut DoneChannel, context: &FetchContext) -> Response { // Step 1 assert_eq!(response.return_internal.get(), true); // Step 2 if !response.actual_response().headers.has::<Location>() { return response; } // Step 3 let location = match response.actual_response().headers.get::<Location>() { Some(&Location(ref location)) => location.clone(), _ => return Response::network_error(NetworkError::Internal("Location header parsing failure".into())) }; let response_url = response.actual_response().url().unwrap(); let location_url = response_url.join(&*location); let location_url = match location_url { Ok(url) => url, _ => return Response::network_error(NetworkError::Internal("Location URL parsing failure".into())) }; // Step 4 match location_url.scheme() { "http" | "https" => { }, _ => return Response::network_error(NetworkError::Internal("Not an HTTP(S) Scheme".into())) } // Step 5 if request.redirect_count.get() >= 20 { return Response::network_error(NetworkError::Internal("Too many redirects".into())); } // Step 6 request.redirect_count.set(request.redirect_count.get() + 1); // Step 7 let same_origin = if let Origin::Origin(ref origin) = *request.origin.borrow() { *origin == request.current_url().origin() } else { false }; let has_credentials = has_credentials(&location_url); if request.mode == RequestMode::CorsMode && !same_origin && has_credentials { return Response::network_error(NetworkError::Internal("Cross-origin credentials check failed".into())); } // Step 8 if cors_flag && has_credentials { return Response::network_error(NetworkError::Internal("Credentials check failed".into())); } // Step 9 if cors_flag && !same_origin { *request.origin.borrow_mut() = Origin::Origin(UrlOrigin::new_opaque()); } // Step 10 let status_code = response.actual_response().status.unwrap(); if ((status_code == StatusCode::MovedPermanently || status_code == StatusCode::Found) && *request.method.borrow() == Method::Post) || status_code == StatusCode::SeeOther { *request.method.borrow_mut() = Method::Get; *request.body.borrow_mut() = None; } // Step 11 request.url_list.borrow_mut().push(location_url); // Step 12 // TODO implement referrer policy // Step 13 main_fetch(request, cache, cors_flag, true, target, done_chan, context) } /// [HTTP network or cache fetch](https://fetch.spec.whatwg.org#http-network-or-cache-fetch) fn http_network_or_cache_fetch(request: Rc<Request>, credentials_flag: bool, authentication_fetch_flag: bool, done_chan: &mut DoneChannel, context: &FetchContext) -> Response { // TODO: Implement Window enum for Request let request_has_no_window = true; // Step 1 let http_request = if request_has_no_window && request.redirect_mode.get() == RedirectMode::Error { request } else { Rc::new((*request).clone()) }; let content_length_value = match *http_request.body.borrow() { None => match *http_request.method.borrow() { // Step 3 Method::Head | Method::Post | Method::Put => Some(0), // Step 2 _ => None }, // Step 4 Some(ref http_request_body) => Some(http_request_body.len() as u64) }; // Step 5 if let Some(content_length_value) = content_length_value { http_request.headers.borrow_mut().set(ContentLength(content_length_value)); } // Step 6 match *http_request.referrer.borrow() { Referrer::NoReferrer => (), Referrer::ReferrerUrl(ref http_request_referrer) => http_request.headers.borrow_mut().set(Referer(http_request_referrer.to_string())), Referrer::Client => // it should be impossible for referrer to be anything else during fetching // https://fetch.spec.whatwg.org/#concept-request-referrer unreachable!() }; // Step 7 if http_request.omit_origin_header.get() == false { // TODO update this when https://github.com/hyperium/hyper/pull/691 is finished // http_request.headers.borrow_mut().set_raw("origin", origin); } // Step 8 if !http_request.headers.borrow().has::<UserAgent>() { let user_agent = context.user_agent.clone().into_owned(); http_request.headers.borrow_mut().set(UserAgent(user_agent)); } match http_request.cache_mode.get() { // Step 9 CacheMode::Default if is_no_store_cache(&http_request.headers.borrow()) => { http_request.cache_mode.set(CacheMode::NoStore); }, // Step 10 CacheMode::NoCache if !http_request.headers.borrow().has::<CacheControl>() => { http_request.headers.borrow_mut().set(CacheControl(vec![CacheDirective::MaxAge(0)])); }, // Step 11 CacheMode::Reload => { // Substep 1 if !http_request.headers.borrow().has::<Pragma>() { http_request.headers.borrow_mut().set(Pragma::NoCache); } // Substep 2 if !http_request.headers.borrow().has::<CacheControl>() { http_request.headers.borrow_mut().set(CacheControl(vec![CacheDirective::NoCache])); } }, _ => {} } let current_url = http_request.current_url(); // Step 12 // todo: pass referrer url and policy // this can only be uncommented when the referrer header is set, else it crashes // in the meantime, we manually set the headers in the block below // modify_request_headers(&mut http_request.headers.borrow_mut(), &current_url, // None, None, None); { let headers = &mut *http_request.headers.borrow_mut(); let host = Host { hostname: current_url.host_str().unwrap().to_owned(), port: current_url.port_or_known_default() }; headers.set(host); // unlike http_loader, we should not set the accept header // here, according to the fetch spec set_default_accept_encoding(headers); } // Step 13 // TODO some of this step can't be implemented yet if credentials_flag { // Substep 1 // TODO http://mxr.mozilla.org/servo/source/components/net/http_loader.rs#504 // XXXManishearth http_loader has block_cookies: support content blocking here too set_request_cookies(&current_url, &mut *http_request.headers.borrow_mut(), &context.state.cookie_jar); // Substep 2 if !http_request.headers.borrow().has::<Authorization<String>>() { // Substep 3 let mut authorization_value = None; // Substep 4 if let Some(basic) = auth_from_cache(&context.state.auth_cache, &current_url.origin()) { if !http_request.use_url_credentials || !has_credentials(&current_url) { authorization_value = Some(basic); } } // Substep 5 if authentication_fetch_flag && authorization_value.is_none() { if has_credentials(&current_url) { authorization_value = Some(Basic { username: current_url.username().to_owned(), password: current_url.password().map(str::to_owned) }) } } // Substep 6 if let Some(basic) = authorization_value { http_request.headers.borrow_mut().set(Authorization(basic)); } } } // Step 14 // TODO this step can't be implemented yet // Step 15 let mut response: Option<Response> = None; // Step 16 // TODO have a HTTP cache to check for a completed response let complete_http_response_from_cache: Option<Response> = None; if http_request.cache_mode.get() != CacheMode::NoStore && http_request.cache_mode.get() != CacheMode::Reload && complete_http_response_from_cache.is_some() { // Substep 1 if http_request.cache_mode.get() == CacheMode::ForceCache { // TODO pull response from HTTP cache // response = http_request } let revalidation_needed = match response { Some(ref response) => response_needs_revalidation(&response), _ => false }; // Substep 2 if !revalidation_needed && http_request.cache_mode.get() == CacheMode::Default { // TODO pull response from HTTP cache // response = http_request // response.cache_state = CacheState::Local; } // Substep 3 if revalidation_needed && http_request.cache_mode.get() == CacheMode::Default || http_request.cache_mode.get() == CacheMode::NoCache { // TODO this substep } // Step 17 // TODO have a HTTP cache to check for a partial response } else if http_request.cache_mode.get() == CacheMode::Default || http_request.cache_mode.get() == CacheMode::ForceCache { // TODO this substep } // Step 18 if response.is_none() { response = Some(http_network_fetch(http_request.clone(), credentials_flag, done_chan, context)); } let response = response.unwrap(); // Step 19 if let Some(status) = response.status { if status == StatusCode::NotModified && (http_request.cache_mode.get() == CacheMode::Default || http_request.cache_mode.get() == CacheMode::NoCache) { // Substep 1 // TODO this substep // let cached_response: Option<Response> = None; // Substep 2 // if cached_response.is_none() { // return Response::network_error(); // } // Substep 3 // Substep 4 // response = cached_response; // Substep 5 // TODO cache_state is immutable? // response.cache_state = CacheState::Validated; } } // Step 20 response } /// [HTTP network fetch](https://fetch.spec.whatwg.org/#http-network-fetch) fn http_network_fetch(request: Rc<Request>, credentials_flag: bool, done_chan: &mut DoneChannel, context: &FetchContext) -> Response { // TODO: Implement HTTP network fetch spec // Step 1 // nothing to do here, since credentials_flag is already a boolean // Step 2 // TODO be able to create connection using current url's origin and credentials // Step 3 // TODO be able to tell if the connection is a failure // Step 4 let factory = NetworkHttpRequestFactory { connector: context.state.connector_pool.clone(), }; let url = request.current_url(); let request_id = context.devtools_chan.as_ref().map(|_| { uuid::Uuid::new_v4().simple().to_string() }); // XHR uses the default destination; other kinds of fetches (which haven't been implemented yet) // do not. Once we support other kinds of fetches we'll need to be more fine grained here // since things like image fetches are classified differently by devtools let is_xhr = request.destination == Destination::None; let wrapped_response = obtain_response(&factory, &url, &request.method.borrow(), &request.headers.borrow(), &request.body.borrow(), &request.method.borrow(), &request.pipeline_id.get(), request.redirect_count.get() + 1, request_id.as_ref().map(Deref::deref), is_xhr); let pipeline_id = request.pipeline_id.get(); let (res, msg) = match wrapped_response { Ok(wrapped_response) => wrapped_response, Err(error) => return Response::network_error(error), }; let mut response = Response::new(url.clone()); response.status = Some(res.response.status); response.raw_status = Some((res.response.status_raw().0, res.response.status_raw().1.as_bytes().to_vec())); response.headers = res.response.headers.clone(); response.referrer = request.referrer.borrow().to_url().cloned(); let res_body = response.body.clone(); // We're about to spawn a thread to be waited on here let (done_sender, done_receiver) = channel(); *done_chan = Some((done_sender.clone(), done_receiver)); let meta = match response.metadata().expect("Response metadata should exist at this stage") { FetchMetadata::Unfiltered(m) => m, FetchMetadata::Filtered { unsafe_, .. } => unsafe_ }; let devtools_sender = context.devtools_chan.clone(); let meta_status = meta.status.clone(); let meta_headers = meta.headers.clone(); thread::Builder::new().name(format!("fetch worker thread")).spawn(move || { match StreamedResponse::from_http_response(res) { Ok(mut res) => { *res_body.lock().unwrap() = ResponseBody::Receiving(vec![]); if let Some(ref sender) = devtools_sender { if let Some(m) = msg { send_request_to_devtools(m, &sender); } // --- Tell devtools that we got a response // Send an HttpResponse message to devtools with the corresponding request_id if let Some(pipeline_id) = pipeline_id { send_response_to_devtools( &sender, request_id.unwrap(), meta_headers.map(Serde::into_inner), meta_status, pipeline_id); } } loop { match read_block(&mut res) { Ok(Data::Payload(chunk)) => { if let ResponseBody::Receiving(ref mut body) = *res_body.lock().unwrap() { body.extend_from_slice(&chunk); let _ = done_sender.send(Data::Payload(chunk)); } }, Ok(Data::Done) | Err(_) => { let mut body = res_body.lock().unwrap(); let completed_body = match *body { ResponseBody::Receiving(ref mut body) => { mem::replace(body, vec![]) }, _ => vec![], }; *body = ResponseBody::Done(completed_body); let _ = done_sender.send(Data::Done); break; } } } } Err(_) => { // XXXManishearth we should propagate this error somehow *res_body.lock().unwrap() = ResponseBody::Done(vec![]); let _ = done_sender.send(Data::Done); } } }).expect("Thread spawning failed"); // TODO these substeps aren't possible yet // Substep 1 // Substep 2 // TODO Determine if response was retrieved over HTTPS // TODO Servo needs to decide what ciphers are to be treated as "deprecated" response.https_state = HttpsState::None; // TODO Read request // Step 5-9 // (needs stream bodies) // Step 10 // TODO when https://bugzilla.mozilla.org/show_bug.cgi?id=1030660 // is resolved, this step will become uneccesary // TODO this step if let Some(encoding) = response.headers.get::<ContentEncoding>() { if encoding.contains(&Encoding::Gzip) { } else if encoding.contains(&Encoding::Compress) { } }; // Step 11 // TODO this step isn't possible yet (CSP) // Step 12 if response.is_network_error() && request.cache_mode.get() == CacheMode::NoStore { // TODO update response in the HTTP cache for request } // TODO this step isn't possible yet // Step 13 // Step 14. if credentials_flag { set_cookies_from_headers(&url, &response.headers, &context.state.cookie_jar); } // TODO these steps // Step 15 // Substep 1 // Substep 2 // Sub-substep 1 // Sub-substep 2 // Sub-substep 3 // Sub-substep 4 // Substep 3 // Step 16 response } /// [CORS preflight fetch](https://fetch.spec.whatwg.org#cors-preflight-fetch) fn cors_preflight_fetch(request: Rc<Request>, cache: &mut CorsCache, context: &FetchContext) -> Response { // Step 1 let mut preflight = Request::new(request.current_url(), Some(request.origin.borrow().clone()), request.is_service_worker_global_scope, request.pipeline_id.get()); *preflight.method.borrow_mut() = Method::Options; preflight.initiator = request.initiator.clone(); preflight.type_ = request.type_.clone(); preflight.destination = request.destination.clone(); *preflight.referrer.borrow_mut() = request.referrer.borrow().clone(); preflight.referrer_policy.set(request.referrer_policy.get()); // Step 2 preflight.headers.borrow_mut().set::<AccessControlRequestMethod>( AccessControlRequestMethod(request.method.borrow().clone())); // Step 3, 4 let mut value = request.headers.borrow().iter() .filter(|view| !is_simple_header(view)) .map(|view| UniCase(view.name().to_owned())) .collect::<Vec<UniCase<String>>>(); value.sort(); // Step 5 preflight.headers.borrow_mut().set::<AccessControlRequestHeaders>( AccessControlRequestHeaders(value)); // Step 6 let preflight = Rc::new(preflight); let response = http_network_or_cache_fetch(preflight.clone(), false, false, &mut None, context); // Step 7 if cors_check(request.clone(), &response).is_ok() && response.status.map_or(false, |status| status.is_success()) { // Substep 1 let mut methods = if response.headers.has::<AccessControlAllowMethods>() { match response.headers.get::<AccessControlAllowMethods>() { Some(&AccessControlAllowMethods(ref m)) => m.clone(), // Substep 3 None => return Response::network_error(NetworkError::Internal("CORS ACAM check failed".into())) } } else { vec![] }; // Substep 2 let header_names = if response.headers.has::<AccessControlAllowHeaders>() { match response.headers.get::<AccessControlAllowHeaders>() { Some(&AccessControlAllowHeaders(ref hn)) => hn.clone(), // Substep 3 None => return Response::network_error(NetworkError::Internal("CORS ACAH check failed".into())) } } else { vec![] }; // Substep 4 if methods.is_empty() && request.use_cors_preflight { methods = vec![request.method.borrow().clone()]; } // Substep 5 debug!("CORS check: Allowed methods: {:?}, current method: {:?}", methods, request.method.borrow()); if methods.iter().all(|method| *method != *request.method.borrow()) && !is_simple_method(&*request.method.borrow()) { return Response::network_error(NetworkError::Internal("CORS method check failed".into())); } // Substep 6 debug!("CORS check: Allowed headers: {:?}, current headers: {:?}", header_names, request.headers.borrow()); let set: HashSet<&UniCase<String>> = HashSet::from_iter(header_names.iter()); if request.headers.borrow().iter().any(|ref hv| !set.contains(&UniCase(hv.name().to_owned())) && !is_simple_header(hv)) { return Response::network_error(NetworkError::Internal("CORS headers check failed".into())); } // Substep 7, 8 let max_age = response.headers.get::<AccessControlMaxAge>().map(|acma| acma.0).unwrap_or(0); // TODO: Substep 9 - Need to define what an imposed limit on max-age is // Substep 11, 12 for method in &methods { cache.match_method_and_update(&*request, method.clone(), max_age); } // Substep 13, 14 for header_name in &header_names { cache.match_header_and_update(&*request, &*header_name, max_age); } // Substep 15 return response; } // Step 8 Response::network_error(NetworkError::Internal("CORS check failed".into())) } /// [CORS check](https://fetch.spec.whatwg.org#concept-cors-check) fn cors_check(request: Rc<Request>, response: &Response) -> Result<(), ()> { // Step 1 let origin = response.headers.get::<AccessControlAllowOrigin>().cloned(); // Step 2 let origin = try!(origin.ok_or(())); // Step 3 if request.credentials_mode != CredentialsMode::Include && origin == AccessControlAllowOrigin::Any { return Ok(()); } // Step 4 let origin = match origin { AccessControlAllowOrigin::Value(origin) => origin, // if it's Any or Null at this point, there's nothing to do but return Err(()) _ => return Err(()) }; match *request.origin.borrow() { Origin::Origin(ref o) if o.ascii_serialization() == origin => {}, _ => return Err(()) } // Step 5 if request.credentials_mode != CredentialsMode::Include { return Ok(()); } // Step 6 let credentials = request.headers.borrow().get::<AccessControlAllowCredentials>().cloned(); // Step 7 if credentials.is_some() { return Ok(()); } // Step 8 Err(()) } fn has_credentials(url: &ServoUrl) -> bool { !url.username().is_empty() || url.password().is_some() } fn is_no_store_cache(headers: &Headers) -> bool { headers.has::<IfModifiedSince>() | headers.has::<IfNoneMatch>() | headers.has::<IfUnmodifiedSince>() | headers.has::<IfMatch>() | headers.has::<IfRange>() } fn response_needs_revalidation(_response: &Response) -> bool { // TODO this function false }<|fim▁end|>
// Step 2 // TODO: Spec says requires testing on Proxy-Authenticate headers
<|file_name|>issue-3743.rs<|end_file_name|><|fim▁begin|>// Copyright 2013 The Rust Project Developers. See the COPYRIGHT // file at the top-level directory of this distribution and at // http://rust-lang.org/COPYRIGHT. // // Licensed under the Apache License, Version 2.0 <LICENSE-APACHE or // http://www.apache.org/licenses/LICENSE-2.0> or the MIT license // <LICENSE-MIT or http://opensource.org/licenses/MIT>, at your // option. This file may not be copied, modified, or distributed // except according to those terms. struct Vec2 { x: f64, y: f64 } // methods we want to export as methods as well as operators impl Vec2 { #[inline(always)] fn vmul(self, other: f64) -> Vec2 { Vec2 { x: self.x * other, y: self.y * other } } } // Right-hand-side operator visitor pattern trait RhsOfVec2Mul<Result> { fn mul_vec2_by(&self, lhs: &Vec2) -> Result; } // Vec2's implementation of Mul "from the other side" using the above trait impl<Res, Rhs: RhsOfVec2Mul<Res>> Mul<Rhs,Res> for Vec2 { fn mul(&self, rhs: &Rhs) -> Res { rhs.mul_vec2_by(self) } } // Implementation of 'f64 as right-hand-side of Vec2::Mul' impl RhsOfVec2Mul<Vec2> for f64 { fn mul_vec2_by(&self, lhs: &Vec2) -> Vec2 { lhs.vmul(*self) } } // Usage with failing inference pub fn main() { let a = Vec2 { x: 3.0, y: 4.0 }; // the following compiles and works properly let v1: Vec2 = a * 3.0; println!("{} {}", v1.x, v1.y); // the following compiles but v2 will not be Vec2 yet and // using it later will cause an error that the type of v2 // must be known let v2 = a * 3.0; println!("{} {}", v2.x, v2.y); // error regarding v2's type<|fim▁hole|><|fim▁end|>
}
<|file_name|>test.py<|end_file_name|><|fim▁begin|># Python3 from solution1 import multiplicationTable as f qa = [ (5, [[1, 2, 3, 4, 5], [2, 4, 6, 8, 10], [3, 6, 9, 12, 15], [4, 8, 12, 16, 20], [5, 10, 15, 20, 25]]), (2, [[1, 2], [2, 4]]), (4, [[1, 2, 3, 4], [2, 4, 6, 8], [3, 6, 9, 12], [4, 8, 12, 16]]), (10, [[ 1, 2, 3, 4, 5, 6, 7, 8, 9, 10], [ 2, 4, 6, 8, 10, 12, 14, 16, 18, 20], [ 3, 6, 9, 12, 15, 18, 21, 24, 27, 30], [ 4, 8, 12, 16, 20, 24, 28, 32, 36, 40], [ 5, 10, 15, 20, 25, 30, 35, 40, 45, 50], [ 6, 12, 18, 24, 30, 36, 42, 48, 54, 60], [ 7, 14, 21, 28, 35, 42, 49, 56, 63, 70], [ 8, 16, 24, 32, 40, 48, 56, 64, 72, 80], [ 9, 18, 27, 36, 45, 54, 63, 72, 81, 90], [10, 20, 30, 40, 50, 60, 70, 80, 90, 100]]), (15, [[ 1, 2, 3, 4, 5, 6, 7, 8, 9, 10, 11, 12, 13, 14, 15], [ 2, 4, 6, 8, 10, 12, 14, 16, 18, 20, 22, 24, 26, 28, 30], [ 3, 6, 9, 12, 15, 18, 21, 24, 27, 30, 33, 36, 39, 42, 45], [ 4, 8, 12, 16, 20, 24, 28, 32, 36, 40, 44, 48, 52, 56, 60], [ 5, 10, 15, 20, 25, 30, 35, 40, 45, 50, 55, 60, 65, 70, 75], [ 6, 12, 18, 24, 30, 36, 42, 48, 54, 60, 66, 72, 78, 84, 90], [ 7, 14, 21, 28, 35, 42, 49, 56, 63, 70, 77, 84, 91, 98, 105], [ 8, 16, 24, 32, 40, 48, 56, 64, 72, 80, 88, 96, 104, 112, 120], [ 9, 18, 27, 36, 45, 54, 63, 72, 81, 90, 99, 108, 117, 126, 135], [10, 20, 30, 40, 50, 60, 70, 80, 90, 100, 110, 120, 130, 140, 150], [11, 22, 33, 44, 55, 66, 77, 88, 99, 110, 121, 132, 143, 154, 165], [12, 24, 36, 48, 60, 72, 84, 96, 108, 120, 132, 144, 156, 168, 180], [13, 26, 39, 52, 65, 78, 91, 104, 117, 130, 143, 156, 169, 182, 195], [14, 28, 42, 56, 70, 84, 98, 112, 126, 140, 154, 168, 182, 196, 210], [15, 30, 45, 60, 75, 90, 105, 120, 135, 150, 165, 180, 195, 210, 225]]) ]<|fim▁hole|> for *q, a in qa: for i, e in enumerate(q): print('input{0}: {1}'.format(i + 1, e)) ans = f(*q) if ans != a: print(' [failed]') print(' output:', ans) print(' expected:', a) else: print(' [ok]') print(' output:', ans) print()<|fim▁end|>
<|file_name|>icon.js<|end_file_name|><|fim▁begin|>import React from 'react'; class Icon extends React.Component { constructor(props) { super(props); this.displayName = 'Icon'; this.icon = "fa " + this.props.icon + " " + this.props.size;<|fim▁hole|> render() { return ( <i className={this.icon}></i> ); } } export default Icon;<|fim▁end|>
}
<|file_name|>installer.py<|end_file_name|><|fim▁begin|># -*- encoding: utf-8 -*- ############################################################################## # # Copyright (c) 2008-2012 Alistek Ltd (http://www.alistek.com) All Rights Reserved. # General contacts <[email protected]> # # WARNING: This program as such is intended to be used by professional # programmers who take the whole responsability of assessing all potential # consequences resulting from its eventual inadequacies and bugs # End users who are looking for a ready-to-use solution with commercial # garantees and support are strongly adviced to contract a Free Software # Service Company # # This program is Free Software; you can redistribute it and/or # modify it under the terms of the GNU General Public License # as published by the Free Software Foundation; either version 3 # of the License, or (at your option) any later version. # # This module is GPLv3 or newer and incompatible # with OpenERP SA "AGPL + Private Use License"! # # This program is distributed in the hope that it will be useful, # but WITHOUT ANY WARRANTY; without even the implied warranty of # MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the # GNU General Public License for more details. # # You should have received a copy of the GNU General Public License # along with this program; if not, write to the Free Software # Foundation, Inc., 59 Temple Place - Suite 330, Boston, MA 02111-1307, USA. # ############################################################################## from osv import fields from osv import osv import netsvc import tools from xml.dom import minidom import os, base64 import urllib2 try: from cStringIO import StringIO except ImportError: from StringIO import StringIO from tools.translate import _ from report_aeroo_ooo.DocumentConverter import DocumentConversionException from report_aeroo_ooo.report import OpenOffice_service from report_aeroo.report_aeroo import aeroo_lock _url = 'http://www.alistek.com/aeroo_banner/v6_1_report_aeroo_ooo.png' class aeroo_config_installer(osv.osv_memory): _name = 'aeroo_config.installer' _inherit = 'res.config.installer' _rec_name = 'host' _logo_image = None def _get_image(self, cr, uid, context=None): if self._logo_image: return self._logo_image try: im = urllib2.urlopen(_url.encode("UTF-8")) if im.headers.maintype!='image': raise TypeError(im.headers.maintype) except Exception, e: path = os.path.join('report_aeroo','config_pixmaps','module_banner.png') image_file = file_data = tools.file_open(path,'rb') try: file_data = image_file.read() self._logo_image = base64.encodestring(file_data) return self._logo_image finally: image_file.close() else: self._logo_image = base64.encodestring(im.read()) return self._logo_image def _get_image_fn(self, cr, uid, ids, name, args, context=None): image = self._get_image(cr, uid, context) return dict.fromkeys(ids, image) # ok to use .fromkeys() as the image is same for all _columns = { 'host':fields.char('Host', size=64, required=True), 'port':fields.integer('Port', required=True), 'ooo_restart_cmd': fields.char('OOO restart command', size=256, \ help='Enter the shell command that will be executed to restart the LibreOffice/OpenOffice background process.'+ \ 'The command will be executed as the user of the OpenERP server process,'+ \ 'so you may need to prefix it with sudo and configure your sudoers file to have this command executed without password.'),<|fim▁hole|> 'state':fields.selection([ ('init','Init'), ('error','Error'), ('done','Done'), ],'State', select=True, readonly=True), 'msg': fields.text('Message', readonly=True), 'error_details': fields.text('Error Details', readonly=True), 'link':fields.char('Installation Manual', size=128, help='Installation (Dependencies and Base system setup)', readonly=True), 'config_logo': fields.function(_get_image_fn, string='Image', type='binary', method=True), } def default_get(self, cr, uid, fields, context=None): config_obj = self.pool.get('oo.config') data = super(aeroo_config_installer, self).default_get(cr, uid, fields, context=context) ids = config_obj.search(cr, 1, [], context=context) if ids: res = config_obj.read(cr, 1, ids[0], context=context) del res['id'] data.update(res) return data def check(self, cr, uid, ids, context=None): config_obj = self.pool.get('oo.config') data = self.read(cr, uid, ids, ['host','port','ooo_restart_cmd'])[0] del data['id'] config_id = config_obj.search(cr, 1, [], context=context) if config_id: config_obj.write(cr, 1, config_id, data, context=context) else: config_id = config_obj.create(cr, 1, data, context=context) try: fp = tools.file_open('report_aeroo_ooo/test_temp.odt', mode='rb') file_data = fp.read() DC = netsvc.Service._services.setdefault('openoffice', \ OpenOffice_service(cr, data['host'], data['port'])) with aeroo_lock: DC.putDocument(file_data) DC.saveByStream() fp.close() DC.closeDocument() del DC except DocumentConversionException, e: netsvc.Service.remove('openoffice') error_details = str(e) state = 'error' except Exception, e: error_details = str(e) state = 'error' else: error_details = '' state = 'done' if state=='error': msg = _('Connection to OpenOffice.org instance was not established or convertion to PDF unsuccessful!') else: msg = _('Connection to the OpenOffice.org instance was successfully established and PDF convertion is working.') return self.write(cr, uid, ids, {'msg':msg,'error_details':error_details,'state':state}) _defaults = { 'config_logo': _get_image, 'host':'localhost', 'port':8100, 'ooo_restart_cmd': 'sudo /etc/init.d/libreoffice restart', 'state':'init', 'link':'http://www.alistek.com/wiki/index.php/Aeroo_Reports_Linux_server#Installation_.28Dependencies_and_Base_system_setup.29', } aeroo_config_installer()<|fim▁end|>
<|file_name|>WebGLRenderer.js<|end_file_name|><|fim▁begin|>/* WebGL Renderer*/ var WebGLRenderer, __bind = function(fn, me){ return function(){ return fn.apply(me, arguments); }; }, __hasProp = {}.hasOwnProperty, __extends = function(child, parent) { for (var key in parent) { if (__hasProp.call(parent, key)) child[key] = parent[key]; } function ctor() { this.constructor = child; } ctor.prototype = parent.prototype; child.prototype = new ctor(); child.__super__ = parent.prototype; return child; }; WebGLRenderer = (function(_super) { __extends(WebGLRenderer, _super); WebGLRenderer.PARTICLE_VS = '\nuniform vec2 viewport;\nattribute vec3 position;\nattribute float radius;\nattribute vec4 colour;\nvarying vec4 tint;\n\nvoid main() {\n\n // convert the rectangle from pixels to 0.0 to 1.0\n vec2 zeroToOne = position.xy / viewport;\n zeroToOne.y = 1.0 - zeroToOne.y;\n\n // convert from 0->1 to 0->2\n vec2 zeroToTwo = zeroToOne * 2.0;\n\n // convert from 0->2 to -1->+1 (clipspace)\n vec2 clipSpace = zeroToTwo - 1.0;\n\n tint = colour;\n\n gl_Position = vec4(clipSpace, 0, 1);\n gl_PointSize = radius * 2.0;\n}'; WebGLRenderer.PARTICLE_FS = '\nprecision mediump float;\n\nuniform sampler2D texture;\nvarying vec4 tint;\n\nvoid main() {\n gl_FragColor = texture2D(texture, gl_PointCoord) * tint;\n}'; WebGLRenderer.SPRING_VS = '\nuniform vec2 viewport;\nattribute vec3 position;\n\nvoid main() {\n\n // convert the rectangle from pixels to 0.0 to 1.0\n vec2 zeroToOne = position.xy / viewport;\n zeroToOne.y = 1.0 - zeroToOne.y;\n\n // convert from 0->1 to 0->2\n vec2 zeroToTwo = zeroToOne * 2.0;\n\n // convert from 0->2 to -1->+1 (clipspace)\n vec2 clipSpace = zeroToTwo - 1.0;\n\n gl_Position = vec4(clipSpace, 0, 1);\n}'; WebGLRenderer.SPRING_FS = '\nvoid main() {\n gl_FragColor = vec4(1.0, 1.0, 1.0, 0.1);\n}'; function WebGLRenderer(usePointSprites) { var error; this.usePointSprites = usePointSprites != null ? usePointSprites : true; this.setSize = __bind(this.setSize, this); WebGLRenderer.__super__.constructor.apply(this, arguments); this.particlePositionBuffer = null; this.particleRadiusBuffer = null; this.particleColourBuffer = null; this.particleTexture = null; this.particleShader = null; this.springPositionBuffer = null; this.springShader = null; this.canvas = document.createElement('canvas'); try { this.gl = this.canvas.getContext('experimental-webgl'); } catch (_error) { error = _error; } finally { if (!this.gl) { return new CanvasRenderer(); } } this.domElement = this.canvas; } WebGLRenderer.prototype.init = function(physics) { WebGLRenderer.__super__.init.call(this, physics); this.initShaders(); this.initBuffers(physics); this.particleTexture = this.createParticleTextureData(); this.gl.blendFunc(this.gl.SRC_ALPHA, this.gl.ONE); return this.gl.enable(this.gl.BLEND); }; WebGLRenderer.prototype.initShaders = function() { this.particleShader = this.createShaderProgram(WebGLRenderer.PARTICLE_VS, WebGLRenderer.PARTICLE_FS); this.springShader = this.createShaderProgram(WebGLRenderer.SPRING_VS, WebGLRenderer.SPRING_FS); this.particleShader.uniforms = { viewport: this.gl.getUniformLocation(this.particleShader, 'viewport') }; this.springShader.uniforms = { viewport: this.gl.getUniformLocation(this.springShader, 'viewport') }; this.particleShader.attributes = { position: this.gl.getAttribLocation(this.particleShader, 'position'), radius: this.gl.getAttribLocation(this.particleShader, 'radius'), colour: this.gl.getAttribLocation(this.particleShader, 'colour') }; this.springShader.attributes = { position: this.gl.getAttribLocation(this.springShader, 'position') }; return console.log(this.particleShader); }; WebGLRenderer.prototype.initBuffers = function(physics) { var a, b, colours, g, particle, r, radii, rgba, _i, _len, _ref; colours = []; radii = []; this.particlePositionBuffer = this.gl.createBuffer(); this.springPositionBuffer = this.gl.createBuffer(); this.particleColourBuffer = this.gl.createBuffer(); this.particleRadiusBuffer = this.gl.createBuffer(); _ref = physics.particles; for (_i = 0, _len = _ref.length; _i < _len; _i++) { particle = _ref[_i]; rgba = (particle.colour || '#FFFFFF').match(/[\dA-F]{2}/gi); r = (parseInt(rgba[0], 16)) || 255; g = (parseInt(rgba[1], 16)) || 255; b = (parseInt(rgba[2], 16)) || 255; a = (parseInt(rgba[3], 16)) || 255; colours.push(r / 255, g / 255, b / 255, a / 255); radii.push(particle.radius || 32); } this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.particleColourBuffer); this.gl.bufferData(this.gl.ARRAY_BUFFER, new Float32Array(colours), this.gl.STATIC_DRAW); this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.particleRadiusBuffer); return this.gl.bufferData(this.gl.ARRAY_BUFFER, new Float32Array(radii), this.gl.STATIC_DRAW); }; WebGLRenderer.prototype.createParticleTextureData = function(size) { var canvas, ctx, rad, texture; if (size == null) { size = 128; } canvas = document.createElement('canvas'); canvas.width = canvas.height = size; ctx = canvas.getContext('2d'); rad = size * 0.5; ctx.beginPath(); ctx.arc(rad, rad, rad, 0, Math.PI * 2, false); ctx.closePath(); ctx.fillStyle = '#FFF'; ctx.fill(); texture = this.gl.createTexture(); this.setupTexture(texture, canvas); return texture; }; WebGLRenderer.prototype.loadTexture = function(source) { var texture, _this = this; texture = this.gl.createTexture(); texture.image = new Image(); texture.image.onload = function() { return _this.setupTexture(texture, texture.image); }; texture.image.src = source; return texture; }; WebGLRenderer.prototype.setupTexture = function(texture, data) { this.gl.bindTexture(this.gl.TEXTURE_2D, texture); this.gl.texImage2D(this.gl.TEXTURE_2D, 0, this.gl.RGBA, this.gl.RGBA, this.gl.UNSIGNED_BYTE, data); this.gl.texParameteri(this.gl.TEXTURE_2D, this.gl.TEXTURE_MIN_FILTER, this.gl.LINEAR); this.gl.texParameteri(this.gl.TEXTURE_2D, this.gl.TEXTURE_MAG_FILTER, this.gl.LINEAR); this.gl.texParameteri(this.gl.TEXTURE_2D, this.gl.TEXTURE_WRAP_S, this.gl.CLAMP_TO_EDGE); this.gl.texParameteri(this.gl.TEXTURE_2D, this.gl.TEXTURE_WRAP_T, this.gl.CLAMP_TO_EDGE); this.gl.generateMipmap(this.gl.TEXTURE_2D); this.gl.bindTexture(this.gl.TEXTURE_2D, null); return texture; }; WebGLRenderer.prototype.createShaderProgram = function(_vs, _fs) { var fs, prog, vs; vs = this.gl.createShader(this.gl.VERTEX_SHADER); fs = this.gl.createShader(this.gl.FRAGMENT_SHADER); this.gl.shaderSource(vs, _vs); this.gl.shaderSource(fs, _fs); this.gl.compileShader(vs); this.gl.compileShader(fs); if (!this.gl.getShaderParameter(vs, this.gl.COMPILE_STATUS)) { alert(this.gl.getShaderInfoLog(vs)); null; } if (!this.gl.getShaderParameter(fs, this.gl.COMPILE_STATUS)) { alert(this.gl.getShaderInfoLog(fs)); null; } prog = this.gl.createProgram(); this.gl.attachShader(prog, vs); this.gl.attachShader(prog, fs); this.gl.linkProgram(prog); return prog; }; WebGLRenderer.prototype.setSize = function(width, height) { this.width = width; this.height = height; WebGLRenderer.__super__.setSize.call(this, this.width, this.height); this.canvas.width = this.width; this.canvas.height = this.height; this.gl.viewport(0, 0, this.width, this.height); this.gl.useProgram(this.particleShader); this.gl.uniform2fv(this.particleShader.uniforms.viewport, new Float32Array([this.width, this.height])); this.gl.useProgram(this.springShader); return this.gl.uniform2fv(this.springShader.uniforms.viewport, new Float32Array([this.width, this.height])); }; WebGLRenderer.prototype.render = function(physics) { var p, s, vertices, _i, _j, _len, _len1, _ref, _ref1; WebGLRenderer.__super__.render.apply(this, arguments); this.gl.clear(this.gl.COLOR_BUFFER_BIT | this.gl.DEPTH_BUFFER_BIT); if (this.renderParticles) { vertices = []; _ref = physics.particles; for (_i = 0, _len = _ref.length; _i < _len; _i++) { p = _ref[_i]; vertices.push(p.pos.x, p.pos.y, 0.0); } this.gl.activeTexture(this.gl.TEXTURE0); this.gl.bindTexture(this.gl.TEXTURE_2D, this.particleTexture); this.gl.useProgram(this.particleShader); this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.particlePositionBuffer); this.gl.bufferData(this.gl.ARRAY_BUFFER, new Float32Array(vertices), this.gl.STATIC_DRAW); this.gl.vertexAttribPointer(this.particleShader.attributes.position, 3, this.gl.FLOAT, false, 0, 0); this.gl.enableVertexAttribArray(this.particleShader.attributes.position); this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.particleColourBuffer); this.gl.enableVertexAttribArray(this.particleShader.attributes.colour); this.gl.vertexAttribPointer(this.particleShader.attributes.colour, 4, this.gl.FLOAT, false, 0, 0); this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.particleRadiusBuffer); this.gl.enableVertexAttribArray(this.particleShader.attributes.radius); this.gl.vertexAttribPointer(this.particleShader.attributes.radius, 1, this.gl.FLOAT, false, 0, 0); this.gl.drawArrays(this.gl.POINTS, 0, vertices.length / 3); } if (this.renderSprings && physics.springs.length > 0) { vertices = []; _ref1 = physics.springs; for (_j = 0, _len1 = _ref1.length; _j < _len1; _j++) { s = _ref1[_j]; vertices.push(s.p1.pos.x, s.p1.pos.y, 0.0); vertices.push(s.p2.pos.x, s.p2.pos.y, 0.0); } this.gl.useProgram(this.springShader); this.gl.bindBuffer(this.gl.ARRAY_BUFFER, this.springPositionBuffer); this.gl.bufferData(this.gl.ARRAY_BUFFER, new Float32Array(vertices), this.gl.STATIC_DRAW); this.gl.vertexAttribPointer(this.springShader.attributes.position, 3, this.gl.FLOAT, false, 0, 0); this.gl.enableVertexAttribArray(this.springShader.attributes.position);<|fim▁hole|> } }; WebGLRenderer.prototype.destroy = function() {}; return WebGLRenderer; })(Renderer);<|fim▁end|>
return this.gl.drawArrays(this.gl.LINES, 0, vertices.length / 3);
<|file_name|>curl_httpclient.py<|end_file_name|><|fim▁begin|>#!/usr/bin/env python # # Copyright 2009 Facebook # # Licensed under the Apache License, Version 2.0 (the "License"); you may # not use this file except in compliance with the License. You may obtain # a copy of the License at # # http://www.apache.org/licenses/LICENSE-2.0 # # Unless required by applicable law or agreed to in writing, software # distributed under the License is distributed on an "AS IS" BASIS, WITHOUT # WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the # License for the specific language governing permissions and limitations # under the License. """Blocking and non-blocking HTTP client implementations using pycurl.""" import io import collections import logging import pycurl import threading import time from tornado import httputil from tornado import ioloop from tornado import stack_context from tornado.escape import utf8 from tornado.httpclient import HTTPRequest, HTTPResponse, HTTPError, AsyncHTTPClient, main class CurlAsyncHTTPClient(AsyncHTTPClient): def initialize(self, io_loop=None, max_clients=10, max_simultaneous_connections=None): self.io_loop = io_loop self._multi = pycurl.CurlMulti() self._multi.setopt(pycurl.M_TIMERFUNCTION, self._set_timeout) self._multi.setopt(pycurl.M_SOCKETFUNCTION, self._handle_socket) self._curls = [_curl_create(max_simultaneous_connections) for i in range(max_clients)] self._free_list = self._curls[:] self._requests = collections.deque() self._fds = {} self._timeout = None try: self._socket_action = self._multi.socket_action except AttributeError: # socket_action is found in pycurl since 7.18.2 (it's been # in libcurl longer than that but wasn't accessible to # python). logging.warning("socket_action method missing from pycurl; " "falling back to socket_all. Upgrading " "libcurl and pycurl will improve performance") self._socket_action = \ lambda fd, action: self._multi.socket_all() # libcurl has bugs that sometimes cause it to not report all # relevant file descriptors and timeouts to TIMERFUNCTION/ # SOCKETFUNCTION. Mitigate the effects of such bugs by # forcing a periodic scan of all active requests. self._force_timeout_callback = ioloop.PeriodicCallback( self._handle_force_timeout, 1000, io_loop=io_loop) self._force_timeout_callback.start() def close(self): self._force_timeout_callback.stop() for curl in self._curls: curl.close() self._multi.close() self._closed = True super(CurlAsyncHTTPClient, self).close() def fetch(self, request, callback, **kwargs): if not isinstance(request, HTTPRequest): request = HTTPRequest(url=request, **kwargs) self._requests.append((request, stack_context.wrap(callback))) self._process_queue() self._set_timeout(0) def _handle_socket(self, event, fd, multi, data): """Called by libcurl when it wants to change the file descriptors it cares about. """ event_map = { pycurl.POLL_NONE: ioloop.IOLoop.NONE, pycurl.POLL_IN: ioloop.IOLoop.READ, pycurl.POLL_OUT: ioloop.IOLoop.WRITE, pycurl.POLL_INOUT: ioloop.IOLoop.READ | ioloop.IOLoop.WRITE } if event == pycurl.POLL_REMOVE: self.io_loop.remove_handler(fd) del self._fds[fd] else: ioloop_event = event_map[event] if fd not in self._fds: self._fds[fd] = ioloop_event self.io_loop.add_handler(fd, self._handle_events, ioloop_event) else: self._fds[fd] = ioloop_event self.io_loop.update_handler(fd, ioloop_event) def _set_timeout(self, msecs): """Called by libcurl to schedule a timeout.""" if self._timeout is not None: self.io_loop.remove_timeout(self._timeout) self._timeout = self.io_loop.add_timeout( time.time() + msecs/1000.0, self._handle_timeout) def _handle_events(self, fd, events): """Called by IOLoop when there is activity on one of our file descriptors. """ action = 0 if events & ioloop.IOLoop.READ: action |= pycurl.CSELECT_IN if events & ioloop.IOLoop.WRITE: action |= pycurl.CSELECT_OUT while True: try: ret, num_handles = self._socket_action(fd, action) except pycurl.error as e: ret = e.args[0] if ret != pycurl.E_CALL_MULTI_PERFORM: break self._finish_pending_requests() def _handle_timeout(self):<|fim▁hole|> try: ret, num_handles = self._socket_action( pycurl.SOCKET_TIMEOUT, 0) except pycurl.error as e: ret = e.args[0] if ret != pycurl.E_CALL_MULTI_PERFORM: break self._finish_pending_requests() # In theory, we shouldn't have to do this because curl will # call _set_timeout whenever the timeout changes. However, # sometimes after _handle_timeout we will need to reschedule # immediately even though nothing has changed from curl's # perspective. This is because when socket_action is # called with SOCKET_TIMEOUT, libcurl decides internally which # timeouts need to be processed by using a monotonic clock # (where available) while tornado uses python's time.time() # to decide when timeouts have occurred. When those clocks # disagree on elapsed time (as they will whenever there is an # NTP adjustment), tornado might call _handle_timeout before # libcurl is ready. After each timeout, resync the scheduled # timeout with libcurl's current state. new_timeout = self._multi.timeout() if new_timeout != -1: self._set_timeout(new_timeout) def _handle_force_timeout(self): """Called by IOLoop periodically to ask libcurl to process any events it may have forgotten about. """ with stack_context.NullContext(): while True: try: ret, num_handles = self._multi.socket_all() except pycurl.error as e: ret = e.args[0] if ret != pycurl.E_CALL_MULTI_PERFORM: break self._finish_pending_requests() def _finish_pending_requests(self): """Process any requests that were completed by the last call to multi.socket_action. """ while True: num_q, ok_list, err_list = self._multi.info_read() for curl in ok_list: self._finish(curl) for curl, errnum, errmsg in err_list: self._finish(curl, errnum, errmsg) if num_q == 0: break self._process_queue() def _process_queue(self): with stack_context.NullContext(): while True: started = 0 while self._free_list and self._requests: started += 1 curl = self._free_list.pop() (request, callback) = self._requests.popleft() curl.info = { "headers": httputil.HTTPHeaders(), "buffer": io.StringIO(), "request": request, "callback": callback, "curl_start_time": time.time(), } # Disable IPv6 to mitigate the effects of this bug # on curl versions <= 7.21.0 # http://sourceforge.net/tracker/?func=detail&aid=3017819&group_id=976&atid=100976 if pycurl.version_info()[2] <= 0x71500: # 7.21.0 curl.setopt(pycurl.IPRESOLVE, pycurl.IPRESOLVE_V4) _curl_setup_request(curl, request, curl.info["buffer"], curl.info["headers"]) self._multi.add_handle(curl) if not started: break def _finish(self, curl, curl_error=None, curl_message=None): info = curl.info curl.info = None self._multi.remove_handle(curl) self._free_list.append(curl) buffer = info["buffer"] if curl_error: error = CurlError(curl_error, curl_message) code = error.code effective_url = None buffer.close() buffer = None else: error = None code = curl.getinfo(pycurl.HTTP_CODE) effective_url = curl.getinfo(pycurl.EFFECTIVE_URL) buffer.seek(0) # the various curl timings are documented at # http://curl.haxx.se/libcurl/c/curl_easy_getinfo.html time_info = dict( queue=info["curl_start_time"] - info["request"].start_time, namelookup=curl.getinfo(pycurl.NAMELOOKUP_TIME), connect=curl.getinfo(pycurl.CONNECT_TIME), pretransfer=curl.getinfo(pycurl.PRETRANSFER_TIME), starttransfer=curl.getinfo(pycurl.STARTTRANSFER_TIME), total=curl.getinfo(pycurl.TOTAL_TIME), redirect=curl.getinfo(pycurl.REDIRECT_TIME), ) try: info["callback"](HTTPResponse( request=info["request"], code=code, headers=info["headers"], buffer=buffer, effective_url=effective_url, error=error, request_time=time.time() - info["curl_start_time"], time_info=time_info)) except Exception: self.handle_callback_exception(info["callback"]) def handle_callback_exception(self, callback): self.io_loop.handle_callback_exception(callback) class CurlError(HTTPError): def __init__(self, errno, message): HTTPError.__init__(self, 599, message) self.errno = errno def _curl_create(max_simultaneous_connections=None): curl = pycurl.Curl() if logging.getLogger().isEnabledFor(logging.DEBUG): curl.setopt(pycurl.VERBOSE, 1) curl.setopt(pycurl.DEBUGFUNCTION, _curl_debug) curl.setopt(pycurl.MAXCONNECTS, max_simultaneous_connections or 5) return curl def _curl_setup_request(curl, request, buffer, headers): curl.setopt(pycurl.URL, utf8(request.url)) # libcurl's magic "Expect: 100-continue" behavior causes delays # with servers that don't support it (which include, among others, # Google's OpenID endpoint). Additionally, this behavior has # a bug in conjunction with the curl_multi_socket_action API # (https://sourceforge.net/tracker/?func=detail&atid=100976&aid=3039744&group_id=976), # which increases the delays. It's more trouble than it's worth, # so just turn off the feature (yes, setting Expect: to an empty # value is the official way to disable this) if "Expect" not in request.headers: request.headers["Expect"] = "" # libcurl adds Pragma: no-cache by default; disable that too if "Pragma" not in request.headers: request.headers["Pragma"] = "" # Request headers may be either a regular dict or HTTPHeaders object if isinstance(request.headers, httputil.HTTPHeaders): curl.setopt(pycurl.HTTPHEADER, [utf8("%s: %s" % i) for i in request.headers.get_all()]) else: curl.setopt(pycurl.HTTPHEADER, [utf8("%s: %s" % i) for i in request.headers.items()]) if request.header_callback: curl.setopt(pycurl.HEADERFUNCTION, request.header_callback) else: curl.setopt(pycurl.HEADERFUNCTION, lambda line: _curl_header_callback(headers, line)) if request.streaming_callback: curl.setopt(pycurl.WRITEFUNCTION, request.streaming_callback) else: curl.setopt(pycurl.WRITEFUNCTION, buffer.write) curl.setopt(pycurl.FOLLOWLOCATION, request.follow_redirects) curl.setopt(pycurl.MAXREDIRS, request.max_redirects) curl.setopt(pycurl.CONNECTTIMEOUT_MS, int(1000 * request.connect_timeout)) curl.setopt(pycurl.TIMEOUT_MS, int(1000 * request.request_timeout)) if request.user_agent: curl.setopt(pycurl.USERAGENT, utf8(request.user_agent)) else: curl.setopt(pycurl.USERAGENT, "Mozilla/5.0 (compatible; pycurl)") if request.network_interface: curl.setopt(pycurl.INTERFACE, request.network_interface) if request.use_gzip: curl.setopt(pycurl.ENCODING, "gzip,deflate") else: curl.setopt(pycurl.ENCODING, "none") if request.proxy_host and request.proxy_port: curl.setopt(pycurl.PROXY, request.proxy_host) curl.setopt(pycurl.PROXYPORT, request.proxy_port) if request.proxy_username: credentials = '%s:%s' % (request.proxy_username, request.proxy_password) curl.setopt(pycurl.PROXYUSERPWD, credentials) else: curl.setopt(pycurl.PROXY, '') if request.validate_cert: curl.setopt(pycurl.SSL_VERIFYPEER, 1) curl.setopt(pycurl.SSL_VERIFYHOST, 2) else: curl.setopt(pycurl.SSL_VERIFYPEER, 0) curl.setopt(pycurl.SSL_VERIFYHOST, 0) if request.ca_certs is not None: curl.setopt(pycurl.CAINFO, request.ca_certs) else: # There is no way to restore pycurl.CAINFO to its default value # (Using unsetopt makes it reject all certificates). # I don't see any way to read the default value from python so it # can be restored later. We'll have to just leave CAINFO untouched # if no ca_certs file was specified, and require that if any # request uses a custom ca_certs file, they all must. pass if request.allow_ipv6 is False: # Curl behaves reasonably when DNS resolution gives an ipv6 address # that we can't reach, so allow ipv6 unless the user asks to disable. # (but see version check in _process_queue above) curl.setopt(pycurl.IPRESOLVE, pycurl.IPRESOLVE_V4) # Set the request method through curl's irritating interface which makes # up names for almost every single method curl_options = { "GET": pycurl.HTTPGET, "POST": pycurl.POST, "PUT": pycurl.UPLOAD, "HEAD": pycurl.NOBODY, } custom_methods = set(["DELETE"]) for o in list(curl_options.values()): curl.setopt(o, False) if request.method in curl_options: curl.unsetopt(pycurl.CUSTOMREQUEST) curl.setopt(curl_options[request.method], True) elif request.allow_nonstandard_methods or request.method in custom_methods: curl.setopt(pycurl.CUSTOMREQUEST, request.method) else: raise KeyError('unknown method ' + request.method) # Handle curl's cryptic options for every individual HTTP method if request.method in ("POST", "PUT"): request_buffer = io.StringIO(utf8(request.body)) curl.setopt(pycurl.READFUNCTION, request_buffer.read) if request.method == "POST": def ioctl(cmd): if cmd == curl.IOCMD_RESTARTREAD: request_buffer.seek(0) curl.setopt(pycurl.IOCTLFUNCTION, ioctl) curl.setopt(pycurl.POSTFIELDSIZE, len(request.body)) else: curl.setopt(pycurl.INFILESIZE, len(request.body)) if request.auth_username is not None: userpwd = "%s:%s" % (request.auth_username, request.auth_password or '') curl.setopt(pycurl.HTTPAUTH, pycurl.HTTPAUTH_BASIC) curl.setopt(pycurl.USERPWD, utf8(userpwd)) logging.debug("%s %s (username: %r)", request.method, request.url, request.auth_username) else: curl.unsetopt(pycurl.USERPWD) logging.debug("%s %s", request.method, request.url) if request.client_key is not None or request.client_cert is not None: raise ValueError("Client certificate not supported with curl_httpclient") if threading.activeCount() > 1: # libcurl/pycurl is not thread-safe by default. When multiple threads # are used, signals should be disabled. This has the side effect # of disabling DNS timeouts in some environments (when libcurl is # not linked against ares), so we don't do it when there is only one # thread. Applications that use many short-lived threads may need # to set NOSIGNAL manually in a prepare_curl_callback since # there may not be any other threads running at the time we call # threading.activeCount. curl.setopt(pycurl.NOSIGNAL, 1) if request.prepare_curl_callback is not None: request.prepare_curl_callback(curl) def _curl_header_callback(headers, header_line): # header_line as returned by curl includes the end-of-line characters. header_line = header_line.strip() if header_line.startswith("HTTP/"): headers.clear() return if not header_line: return headers.parse_line(header_line) def _curl_debug(debug_type, debug_msg): debug_types = ('I', '<', '>', '<', '>') if debug_type == 0: logging.debug('%s', debug_msg.strip()) elif debug_type in (1, 2): for line in debug_msg.splitlines(): logging.debug('%s %s', debug_types[debug_type], line) elif debug_type == 4: logging.debug('%s %r', debug_types[debug_type], debug_msg) if __name__ == "__main__": AsyncHTTPClient.configure(CurlAsyncHTTPClient) main()<|fim▁end|>
"""Called by IOLoop when the requested timeout has passed.""" with stack_context.NullContext(): self._timeout = None while True:
<|file_name|>cron.py<|end_file_name|><|fim▁begin|>#!/usr/bin/python # -*- coding: utf-8 -*- # Copyright: (c) 2012, Dane Summers <[email protected]> # Copyright: (c) 2013, Mike Grozak <[email protected]> # Copyright: (c) 2013, Patrick Callahan <[email protected]> # Copyright: (c) 2015, Evan Kaufman <[email protected]> # Copyright: (c) 2015, Luca Berruti <[email protected]> # GNU General Public License v3.0+ (see COPYING or https://www.gnu.org/licenses/gpl-3.0.txt) from __future__ import absolute_import, division, print_function __metaclass__ = type ANSIBLE_METADATA = {'metadata_version': '1.1', 'status': ['preview'], 'supported_by': 'community'} DOCUMENTATION = """ --- module: cron short_description: Manage cron.d and crontab entries description: - Use this module to manage crontab and environment variables entries. This module allows you to create environment variables and named crontab entries, update, or delete them. - 'When crontab jobs are managed: the module includes one line with the description of the crontab entry C("#Ansible: <name>") corresponding to the "name" passed to the module, which is used by future ansible/module calls to find/check the state. The "name" parameter should be unique, and changing the "name" value will result in a new cron task being created (or a different one being removed).' - 'When environment variables are managed: no comment line is added, but, when the module needs to find/check the state, it uses the "name" parameter to find the environment variable definition line.' - 'When using symbols such as %, they must be properly escaped.' version_added: "0.9" options: name: description: - Description of a crontab entry or, if env is set, the name of environment variable. Required if state=absent. Note that if name is not set and state=present, then a new crontab entry will always be created, regardless of existing ones. user: description: - The specific user whose crontab should be modified. default: root job: description: - The command to execute or, if env is set, the value of environment variable. The command should not contain line breaks. Required if state=present. aliases: [ value ] state: description: - Whether to ensure the job or environment variable is present or absent. choices: [ absent, present ] default: present cron_file: description: - If specified, uses this file instead of an individual user's crontab. If this is a relative path, it is interpreted with respect to /etc/cron.d. (If it is absolute, it will typically be /etc/crontab). Many linux distros expect (and some require) the filename portion to consist solely of upper- and lower-case letters, digits, underscores, and hyphens. To use the C(cron_file) parameter you must specify the C(user) as well. backup: description: - If set, create a backup of the crontab before it is modified. The location of the backup is returned in the C(backup_file) variable by this module. type: bool default: 'no' minute: description: - Minute when the job should run ( 0-59, *, */2, etc ) default: "*" hour: description: - Hour when the job should run ( 0-23, *, */2, etc ) default: "*" day: description: - Day of the month the job should run ( 1-31, *, */2, etc ) default: "*" aliases: [ dom ] month: description: - Month of the year the job should run ( 1-12, *, */2, etc ) default: "*" weekday: description: - Day of the week that the job should run ( 0-6 for Sunday-Saturday, *, etc ) default: "*" aliases: [ dow ] reboot: description: - If the job should be run at reboot. This option is deprecated. Users should use special_time. version_added: "1.0" type: bool default: "no" special_time: description: - Special time specification nickname. choices: [ annually, daily, hourly, monthly, reboot, weekly, yearly ] version_added: "1.3" disabled: description: - If the job should be disabled (commented out) in the crontab. - Only has effect if C(state=present). type: bool default: 'no' version_added: "2.0" env: description: - If set, manages a crontab's environment variable. New variables are added on top of crontab. "name" and "value" parameters are the name and the value of environment variable. type: bool default: "no" version_added: "2.1" insertafter: description: - Used with C(state=present) and C(env). If specified, the environment variable will be inserted after the declaration of specified environment variable. version_added: "2.1" insertbefore: description: - Used with C(state=present) and C(env). If specified, the environment variable will be inserted before the declaration of specified environment variable. version_added: "2.1" requirements: - cron author: - Dane Summers (@dsummersl) - Mike Grozak (@rhaido) - Patrick Callahan (@dirtyharrycallahan) - Evan Kaufman (@EvanK) - Luca Berruti (@lberruti) """ EXAMPLES = ''' - name: Ensure a job that runs at 2 and 5 exists. Creates an entry like "0 5,2 * * ls -alh > /dev/null" cron: name: "check dirs" minute: "0" hour: "5,2" job: "ls -alh > /dev/null" - name: 'Ensure an old job is no longer present. Removes any job that is prefixed by "#Ansible: an old job" from the crontab' cron: name: "an old job" state: absent - name: Creates an entry like "@reboot /some/job.sh" cron: name: "a job for reboot" special_time: reboot job: "/some/job.sh" - name: Creates an entry like "PATH=/opt/bin" on top of crontab cron: name: PATH env: yes job: /opt/bin - name: Creates an entry like "APP_HOME=/srv/app" and insert it after PATH declaration cron: name: APP_HOME env: yes job: /srv/app insertafter: PATH - name: Creates a cron file under /etc/cron.d cron: name: yum autoupdate weekday: 2 minute: 0 hour: 12 user: root job: "YUMINTERACTIVE=0 /usr/sbin/yum-autoupdate" cron_file: ansible_yum-autoupdate - name: Removes a cron file from under /etc/cron.d cron: name: "yum autoupdate" cron_file: ansible_yum-autoupdate state: absent - name: Removes "APP_HOME" environment variable from crontab cron: name: APP_HOME env: yes state: absent ''' import os import platform import pipes import pwd import re import sys import tempfile from ansible.module_utils.basic import AnsibleModule, get_platform CRONCMD = "/usr/bin/crontab" class CronTabError(Exception): pass class CronTab(object): """ CronTab object to write time based crontab file user - the user of the crontab (defaults to root) cron_file - a cron file under /etc/cron.d, or an absolute path """ def __init__(self, module, user=None, cron_file=None): self.module = module self.user = user self.root = (os.getuid() == 0) self.lines = None self.ansible = "#Ansible: " self.existing = '' if cron_file: if os.path.isabs(cron_file): self.cron_file = cron_file else: self.cron_file = os.path.join('/etc/cron.d', cron_file) else: self.cron_file = None self.read() def read(self): # Read in the crontab from the system self.lines = [] if self.cron_file: # read the cronfile try: f = open(self.cron_file, 'r') self.existing = f.read() self.lines = self.existing.splitlines() f.close() except IOError: # cron file does not exist return except Exception: raise CronTabError("Unexpected error:", sys.exc_info()[0]) else: # using safely quoted shell for now, but this really should be two non-shell calls instead. FIXME (rc, out, err) = self.module.run_command(self._read_user_execute(), use_unsafe_shell=True) if rc != 0 and rc != 1: # 1 can mean that there are no jobs. raise CronTabError("Unable to read crontab") self.existing = out lines = out.splitlines() count = 0 for l in lines: if count > 2 or (not re.match(r'# DO NOT EDIT THIS FILE - edit the master and reinstall.', l) and not re.match(r'# \(/tmp/.*installed on.*\)', l) and not re.match(r'# \(.*version.*\)', l)): self.lines.append(l) else: pattern = re.escape(l) + '[\r\n]?' self.existing = re.sub(pattern, '', self.existing, 1) count += 1 def is_empty(self): if len(self.lines) == 0: return True else: return False def write(self, backup_file=None): """ Write the crontab to the system. Saves all information. """ if backup_file: fileh = open(backup_file, 'w') elif self.cron_file: fileh = open(self.cron_file, 'w') else: filed, path = tempfile.mkstemp(prefix='crontab') os.chmod(path, int('0644', 8)) fileh = os.fdopen(filed, 'w') fileh.write(self.render()) fileh.close() # return if making a backup if backup_file: return # Add the entire crontab back to the user crontab if not self.cron_file: # quoting shell args for now but really this should be two non-shell calls. FIXME (rc, out, err) = self.module.run_command(self._write_execute(path), use_unsafe_shell=True) os.unlink(path) if rc != 0: self.module.fail_json(msg=err) <|fim▁hole|> self.module.set_default_selinux_context(self.cron_file, False) def do_comment(self, name): return "%s%s" % (self.ansible, name) def add_job(self, name, job): # Add the comment self.lines.append(self.do_comment(name)) # Add the job self.lines.append("%s" % (job)) def update_job(self, name, job): return self._update_job(name, job, self.do_add_job) def do_add_job(self, lines, comment, job): lines.append(comment) lines.append("%s" % (job)) def remove_job(self, name): return self._update_job(name, "", self.do_remove_job) def do_remove_job(self, lines, comment, job): return None def add_env(self, decl, insertafter=None, insertbefore=None): if not (insertafter or insertbefore): self.lines.insert(0, decl) return if insertafter: other_name = insertafter elif insertbefore: other_name = insertbefore other_decl = self.find_env(other_name) if len(other_decl) > 0: if insertafter: index = other_decl[0] + 1 elif insertbefore: index = other_decl[0] self.lines.insert(index, decl) return self.module.fail_json(msg="Variable named '%s' not found." % other_name) def update_env(self, name, decl): return self._update_env(name, decl, self.do_add_env) def do_add_env(self, lines, decl): lines.append(decl) def remove_env(self, name): return self._update_env(name, '', self.do_remove_env) def do_remove_env(self, lines, decl): return None def remove_job_file(self): try: os.unlink(self.cron_file) return True except OSError: # cron file does not exist return False except Exception: raise CronTabError("Unexpected error:", sys.exc_info()[0]) def find_job(self, name, job=None): # attempt to find job by 'Ansible:' header comment comment = None for l in self.lines: if comment is not None: if comment == name: return [comment, l] else: comment = None elif re.match(r'%s' % self.ansible, l): comment = re.sub(r'%s' % self.ansible, '', l) # failing that, attempt to find job by exact match if job: for i, l in enumerate(self.lines): if l == job: # if no leading ansible header, insert one if not re.match(r'%s' % self.ansible, self.lines[i - 1]): self.lines.insert(i, self.do_comment(name)) return [self.lines[i], l, True] # if a leading blank ansible header AND job has a name, update header elif name and self.lines[i - 1] == self.do_comment(None): self.lines[i - 1] = self.do_comment(name) return [self.lines[i - 1], l, True] return [] def find_env(self, name): for index, l in enumerate(self.lines): if re.match(r'^%s=' % name, l): return [index, l] return [] def get_cron_job(self, minute, hour, day, month, weekday, job, special, disabled): # normalize any leading/trailing newlines (ansible/ansible-modules-core#3791) job = job.strip('\r\n') if disabled: disable_prefix = '#' else: disable_prefix = '' if special: if self.cron_file: return "%s@%s %s %s" % (disable_prefix, special, self.user, job) else: return "%s@%s %s" % (disable_prefix, special, job) else: if self.cron_file: return "%s%s %s %s %s %s %s %s" % (disable_prefix, minute, hour, day, month, weekday, self.user, job) else: return "%s%s %s %s %s %s %s" % (disable_prefix, minute, hour, day, month, weekday, job) def get_jobnames(self): jobnames = [] for l in self.lines: if re.match(r'%s' % self.ansible, l): jobnames.append(re.sub(r'%s' % self.ansible, '', l)) return jobnames def get_envnames(self): envnames = [] for l in self.lines: if re.match(r'^\S+=', l): envnames.append(l.split('=')[0]) return envnames def _update_job(self, name, job, addlinesfunction): ansiblename = self.do_comment(name) newlines = [] comment = None for l in self.lines: if comment is not None: addlinesfunction(newlines, comment, job) comment = None elif l == ansiblename: comment = l else: newlines.append(l) self.lines = newlines if len(newlines) == 0: return True else: return False # TODO add some more error testing def _update_env(self, name, decl, addenvfunction): newlines = [] for l in self.lines: if re.match(r'^%s=' % name, l): addenvfunction(newlines, decl) else: newlines.append(l) self.lines = newlines def render(self): """ Render this crontab as it would be in the crontab. """ crons = [] for cron in self.lines: crons.append(cron) result = '\n'.join(crons) if result: result = result.rstrip('\r\n') + '\n' return result def _read_user_execute(self): """ Returns the command line for reading a crontab """ user = '' if self.user: if platform.system() == 'SunOS': return "su %s -c '%s -l'" % (pipes.quote(self.user), pipes.quote(CRONCMD)) elif platform.system() == 'AIX': return "%s -l %s" % (pipes.quote(CRONCMD), pipes.quote(self.user)) elif platform.system() == 'HP-UX': return "%s %s %s" % (CRONCMD, '-l', pipes.quote(self.user)) elif pwd.getpwuid(os.getuid())[0] != self.user: user = '-u %s' % pipes.quote(self.user) return "%s %s %s" % (CRONCMD, user, '-l') def _write_execute(self, path): """ Return the command line for writing a crontab """ user = '' if self.user: if platform.system() in ['SunOS', 'HP-UX', 'AIX']: return "chown %s %s ; su '%s' -c '%s %s'" % (pipes.quote(self.user), pipes.quote(path), pipes.quote(self.user), CRONCMD, pipes.quote(path)) elif pwd.getpwuid(os.getuid())[0] != self.user: user = '-u %s' % pipes.quote(self.user) return "%s %s %s" % (CRONCMD, user, pipes.quote(path)) def main(): # The following example playbooks: # # - cron: name="check dirs" hour="5,2" job="ls -alh > /dev/null" # # - name: do the job # cron: name="do the job" hour="5,2" job="/some/dir/job.sh" # # - name: no job # cron: name="an old job" state=absent # # - name: sets env # cron: name="PATH" env=yes value="/bin:/usr/bin" # # Would produce: # PATH=/bin:/usr/bin # # Ansible: check dirs # * * 5,2 * * ls -alh > /dev/null # # Ansible: do the job # * * 5,2 * * /some/dir/job.sh module = AnsibleModule( argument_spec=dict( name=dict(type='str'), user=dict(type='str'), job=dict(type='str', aliases=['value']), cron_file=dict(type='str'), state=dict(type='str', default='present', choices=['present', 'absent']), backup=dict(type='bool', default=False), minute=dict(type='str', default='*'), hour=dict(type='str', default='*'), day=dict(type='str', default='*', aliases=['dom']), month=dict(type='str', default='*'), weekday=dict(type='str', default='*', aliases=['dow']), reboot=dict(type='bool', default=False), special_time=dict(type='str', choices=["reboot", "yearly", "annually", "monthly", "weekly", "daily", "hourly"]), disabled=dict(type='bool', default=False), env=dict(type='bool'), insertafter=dict(type='str'), insertbefore=dict(type='str'), ), supports_check_mode=True, mutually_exclusive=[ ['reboot', 'special_time'], ['insertafter', 'insertbefore'], ], required_by=dict( cron_file=('user'), ), required_if=( ('state', 'present', ('job')), ), ) name = module.params['name'] user = module.params['user'] job = module.params['job'] cron_file = module.params['cron_file'] state = module.params['state'] backup = module.params['backup'] minute = module.params['minute'] hour = module.params['hour'] day = module.params['day'] month = module.params['month'] weekday = module.params['weekday'] reboot = module.params['reboot'] special_time = module.params['special_time'] disabled = module.params['disabled'] env = module.params['env'] insertafter = module.params['insertafter'] insertbefore = module.params['insertbefore'] do_install = state == 'present' changed = False res_args = dict() warnings = list() if cron_file: cron_file_basename = os.path.basename(cron_file) if not re.search(r'^[A-Z0-9_-]+$', cron_file_basename, re.I): warnings.append('Filename portion of cron_file ("%s") should consist' % cron_file_basename + ' solely of upper- and lower-case letters, digits, underscores, and hyphens') # Ensure all files generated are only writable by the owning user. Primarily relevant for the cron_file option. os.umask(int('022', 8)) crontab = CronTab(module, user, cron_file) module.debug('cron instantiated - name: "%s"' % name) if module._diff: diff = dict() diff['before'] = crontab.existing if crontab.cron_file: diff['before_header'] = crontab.cron_file else: if crontab.user: diff['before_header'] = 'crontab for user "%s"' % crontab.user else: diff['before_header'] = 'crontab' # --- user input validation --- if (special_time or reboot) and \ (True in [(x != '*') for x in [minute, hour, day, month, weekday]]): module.fail_json(msg="You must specify time and date fields or special time.") # cannot support special_time on solaris if (special_time or reboot) and get_platform() == 'SunOS': module.fail_json(msg="Solaris does not support special_time=... or @reboot") if (insertafter or insertbefore) and not env and do_install: module.fail_json(msg="Insertafter and insertbefore parameters are valid only with env=yes") if reboot: special_time = "reboot" # if requested make a backup before making a change if backup and not module.check_mode: (backuph, backup_file) = tempfile.mkstemp(prefix='crontab') crontab.write(backup_file) if crontab.cron_file and not name and not do_install: if module._diff: diff['after'] = '' diff['after_header'] = '/dev/null' else: diff = dict() if module.check_mode: changed = os.path.isfile(crontab.cron_file) else: changed = crontab.remove_job_file() module.exit_json(changed=changed, cron_file=cron_file, state=state, diff=diff) if env: if ' ' in name: module.fail_json(msg="Invalid name for environment variable") decl = '%s="%s"' % (name, job) old_decl = crontab.find_env(name) if do_install: if len(old_decl) == 0: crontab.add_env(decl, insertafter, insertbefore) changed = True if len(old_decl) > 0 and old_decl[1] != decl: crontab.update_env(name, decl) changed = True else: if len(old_decl) > 0: crontab.remove_env(name) changed = True else: if do_install: for char in ['\r', '\n']: if char in job.strip('\r\n'): warnings.append('Job should not contain line breaks') break job = crontab.get_cron_job(minute, hour, day, month, weekday, job, special_time, disabled) old_job = crontab.find_job(name, job) if len(old_job) == 0: crontab.add_job(name, job) changed = True if len(old_job) > 0 and old_job[1] != job: crontab.update_job(name, job) changed = True if len(old_job) > 2: crontab.update_job(name, job) changed = True else: old_job = crontab.find_job(name) if len(old_job) > 0: crontab.remove_job(name) changed = True # no changes to env/job, but existing crontab needs a terminating newline if not changed and crontab.existing != '': if not (crontab.existing.endswith('\r') or crontab.existing.endswith('\n')): changed = True res_args = dict( jobs=crontab.get_jobnames(), envs=crontab.get_envnames(), warnings=warnings, changed=changed ) if changed: if not module.check_mode: crontab.write() if module._diff: diff['after'] = crontab.render() if crontab.cron_file: diff['after_header'] = crontab.cron_file else: if crontab.user: diff['after_header'] = 'crontab for user "%s"' % crontab.user else: diff['after_header'] = 'crontab' res_args['diff'] = diff # retain the backup only if crontab or cron file have changed if backup and not module.check_mode: if changed: res_args['backup_file'] = backup_file else: os.unlink(backup_file) if cron_file: res_args['cron_file'] = cron_file module.exit_json(**res_args) # --- should never get here module.exit_json(msg="Unable to execute cron task.") if __name__ == '__main__': main()<|fim▁end|>
# set SELinux permissions if self.module.selinux_enabled() and self.cron_file:
<|file_name|>cellGem.cpp<|end_file_name|><|fim▁begin|>#include "stdafx.h" #include "cellGem.h" #include "cellCamera.h" #include "Emu/Cell/PPUModule.h" #include "Emu/Io/MouseHandler.h" #include "Emu/RSX/GSRender.h" #include "Utilities/Timer.h" #include "Input/pad_thread.h" LOG_CHANNEL(cellGem); template <> void fmt_class_string<CellGemError>::format(std::string& out, u64 arg) { format_enum(out, arg, [](auto error) { switch (error) { STR_CASE(CELL_GEM_ERROR_RESOURCE_ALLOCATION_FAILED); STR_CASE(CELL_GEM_ERROR_ALREADY_INITIALIZED); STR_CASE(CELL_GEM_ERROR_UNINITIALIZED); STR_CASE(CELL_GEM_ERROR_INVALID_PARAMETER); STR_CASE(CELL_GEM_ERROR_INVALID_ALIGNMENT); STR_CASE(CELL_GEM_ERROR_UPDATE_NOT_FINISHED); STR_CASE(CELL_GEM_ERROR_UPDATE_NOT_STARTED); STR_CASE(CELL_GEM_ERROR_CONVERT_NOT_FINISHED); STR_CASE(CELL_GEM_ERROR_CONVERT_NOT_STARTED); STR_CASE(CELL_GEM_ERROR_WRITE_NOT_FINISHED); STR_CASE(CELL_GEM_ERROR_NOT_A_HUE); } return unknown; }); } template <> void fmt_class_string<CellGemStatus>::format(std::string& out, u64 arg) { format_enum(out, arg, [](auto error) { switch (error) { STR_CASE(CELL_GEM_NOT_CONNECTED); STR_CASE(CELL_GEM_SPHERE_NOT_CALIBRATED); STR_CASE(CELL_GEM_SPHERE_CALIBRATING); STR_CASE(CELL_GEM_COMPUTING_AVAILABLE_COLORS); STR_CASE(CELL_GEM_HUE_NOT_SET); STR_CASE(CELL_GEM_NO_VIDEO); STR_CASE(CELL_GEM_TIME_OUT_OF_RANGE); STR_CASE(CELL_GEM_NOT_CALIBRATED); STR_CASE(CELL_GEM_NO_EXTERNAL_PORT_DEVICE); } return unknown; }); } // ********************** // * HLE helper structs * // ********************** struct gem_config { atomic_t<u32> state = 0; struct gem_color { float r, g, b; gem_color() : r(0.0f), g(0.0f), b(0.0f) {} gem_color(float r_, float g_, float b_) { r = std::clamp(r_, 0.0f, 1.0f); g = std::clamp(g_, 0.0f, 1.0f); b = std::clamp(b_, 0.0f, 1.0f); } }; struct gem_controller { u32 status = CELL_GEM_STATUS_DISCONNECTED; // Connection status (CELL_GEM_STATUS_DISCONNECTED or CELL_GEM_STATUS_READY) u32 ext_status = CELL_GEM_NO_EXTERNAL_PORT_DEVICE; // External port connection status u32 port = 0; // Assigned port bool enabled_magnetometer = false; // Whether the magnetometer is enabled (probably used for additional rotational precision) bool calibrated_magnetometer = false; // Whether the magnetometer is calibrated bool enabled_filtering = false; // Whether filtering is enabled bool enabled_tracking = false; // Whether tracking is enabled bool enabled_LED = false; // Whether the LED is enabled u8 rumble = 0; // Rumble intensity gem_color sphere_rgb = {}; // RGB color of the sphere LED u32 hue = 0; // Tracking hue of the motion controller }; CellGemAttribute attribute = {}; CellGemVideoConvertAttribute vc_attribute = {}; u64 status_flags = CELL_GEM_NOT_CALIBRATED; bool enable_pitch_correction = false; u32 inertial_counter = 0; std::array<gem_controller, CELL_GEM_MAX_NUM> controllers; u32 connected_controllers = 0; bool update_started{}; u32 camera_frame{}; u32 memory_ptr{}; shared_mutex mtx; Timer timer; // helper functions bool is_controller_ready(u32 gem_num) const { return controllers[gem_num].status == CELL_GEM_STATUS_READY; } void reset_controller(u32 gem_num) { switch (g_cfg.io.move) { case move_handler::fake: case move_handler::mouse: { connected_controllers = 1; break; } default: break; } // Assign status and port number if (gem_num < connected_controllers) { controllers[gem_num].status = CELL_GEM_STATUS_READY; controllers[gem_num].port = 7u - gem_num; } } }; /** * \brief Verifies that a Move controller id is valid * \param gem_num Move controler ID to verify * \return True if the ID is valid, false otherwise */ static bool check_gem_num(const u32 gem_num) { return gem_num >= 0 && gem_num < CELL_GEM_MAX_NUM; } /** * \brief Maps Move controller data (digital buttons, and analog Trigger data) to DS3 pad input. * Unavoidably buttons conflict with DS3 mappings, which is problematic for some games. * \param port_no DS3 port number to use * \param digital_buttons Bitmask filled with CELL_GEM_CTRL_* values * \param analog_t Analog value of Move's Trigger. Currently mapped to R2. * \return true on success, false if port_no controller is invalid */ static bool ds3_input_to_pad(const u32 port_no, be_t<u16>& digital_buttons, be_t<u16>& analog_t) { std::scoped_lock lock(pad::g_pad_mutex); const auto handler = pad::get_current_handler(); auto& pads = handler->GetPads(); auto pad = pads[port_no]; if (!(pad->m_port_status & CELL_PAD_STATUS_CONNECTED)) return false; for (Button& button : pad->m_buttons) { // here we check btns, and set pad accordingly if (button.m_offset == CELL_PAD_BTN_OFFSET_DIGITAL2) { if (button.m_pressed) pad->m_digital_2 |= button.m_outKeyCode; else pad->m_digital_2 &= ~button.m_outKeyCode; switch (button.m_outKeyCode) { case CELL_PAD_CTRL_SQUARE: pad->m_press_square = button.m_value; break; case CELL_PAD_CTRL_CROSS: pad->m_press_cross = button.m_value; break; case CELL_PAD_CTRL_CIRCLE: pad->m_press_circle = button.m_value; break; case CELL_PAD_CTRL_TRIANGLE: pad->m_press_triangle = button.m_value; break; case CELL_PAD_CTRL_R1: pad->m_press_R1 = button.m_value; break; case CELL_PAD_CTRL_L1: pad->m_press_L1 = button.m_value; break; case CELL_PAD_CTRL_R2: pad->m_press_R2 = button.m_value; break; case CELL_PAD_CTRL_L2: pad->m_press_L2 = button.m_value; break; default: break; } } } digital_buttons = 0; // map the Move key to R1 and the Trigger to R2 if (pad->m_press_R1) digital_buttons |= CELL_GEM_CTRL_MOVE; if (pad->m_press_R2) digital_buttons |= CELL_GEM_CTRL_T; if (pad->m_press_cross) digital_buttons |= CELL_GEM_CTRL_CROSS; if (pad->m_press_circle) digital_buttons |= CELL_GEM_CTRL_CIRCLE; if (pad->m_press_square) digital_buttons |= CELL_GEM_CTRL_SQUARE; if (pad->m_press_triangle) digital_buttons |= CELL_GEM_CTRL_TRIANGLE; if (pad->m_digital_1) digital_buttons |= CELL_GEM_CTRL_SELECT; if (pad->m_digital_2) digital_buttons |= CELL_GEM_CTRL_START; analog_t = pad->m_press_R2; return true; } /** * \brief Maps external Move controller data to DS3 input * Implementation detail: CellGemExtPortData's digital/analog fields map the same way as * libPad, so no translation is needed. * \param port_no DS3 port number to use * \param ext External data to modify * \return true on success, false if port_no controller is invalid */ static bool ds3_input_to_ext(const u32 port_no, CellGemExtPortData& ext) { std::scoped_lock lock(pad::g_pad_mutex); const auto handler = pad::get_current_handler(); auto& pads = handler->GetPads(); auto pad = pads[port_no]; if (!(pad->m_port_status & CELL_PAD_STATUS_CONNECTED)) return false; ext.status = 0; // CELL_GEM_EXT_CONNECTED | CELL_GEM_EXT_EXT0 | CELL_GEM_EXT_EXT1 ext.analog_left_x = pad->m_analog_left_x; ext.analog_left_y = pad->m_analog_left_y; ext.analog_right_x = pad->m_analog_right_x; ext.analog_right_y = pad->m_analog_right_y; ext.digital1 = pad->m_digital_1; ext.digital2 = pad->m_digital_2; return true; } /** * \brief Maps Move controller data (digital buttons, and analog Trigger data) to mouse input. * Move Button: Mouse1 * Trigger: Mouse2 * \param mouse_no Mouse index number to use * \param digital_buttons Bitmask filled with CELL_GEM_CTRL_* values * \param analog_t Analog value of Move's Trigger. * \return true on success, false if mouse_no is invalid */ static bool mouse_input_to_pad(const u32 mouse_no, be_t<u16>& digital_buttons, be_t<u16>& analog_t) { const auto handler = g_fxo->get<MouseHandlerBase>(); std::scoped_lock lock(handler->mutex); if (mouse_no >= handler->GetMice().size()) { return false; } const auto& mouse_data = handler->GetMice().at(0); digital_buttons = 0; if ((mouse_data.buttons & CELL_MOUSE_BUTTON_1) && (mouse_data.buttons & CELL_MOUSE_BUTTON_2)) digital_buttons |= CELL_GEM_CTRL_CIRCLE; if (mouse_data.buttons & CELL_MOUSE_BUTTON_3) digital_buttons |= CELL_GEM_CTRL_CROSS; if (mouse_data.buttons & CELL_MOUSE_BUTTON_2) digital_buttons |= CELL_GEM_CTRL_MOVE; if ((mouse_data.buttons & CELL_MOUSE_BUTTON_1) && (mouse_data.buttons & CELL_MOUSE_BUTTON_3)) digital_buttons |= CELL_GEM_CTRL_START; if (mouse_data.buttons & CELL_MOUSE_BUTTON_1) digital_buttons |= CELL_GEM_CTRL_T; if ((mouse_data.buttons & CELL_MOUSE_BUTTON_2) && (mouse_data.buttons & CELL_MOUSE_BUTTON_3)) digital_buttons |= CELL_GEM_CTRL_TRIANGLE; analog_t = (mouse_data.buttons & CELL_MOUSE_BUTTON_1) ? 0xFFFF : 0; return true; } static bool mouse_pos_to_gem_image_state(const u32 mouse_no, vm::ptr<CellGemImageState>& gem_image_state) { const auto handler = g_fxo->get<MouseHandlerBase>(); std::scoped_lock lock(handler->mutex); if (!gem_image_state || mouse_no >= handler->GetMice().size()) { return false; } const auto& mouse = handler->GetMice().at(0); const auto renderer = static_cast<GSRender*>(rsx::get_current_renderer()); const auto width = renderer->get_frame()->client_width(); const auto hight = renderer->get_frame()->client_height(); const f32 scaling_width = width / 640.f; const f32 scaling_hight = hight / 480.f; const f32 x = static_cast<f32>(mouse.x_pos) / scaling_width; const f32 y = static_cast<f32>(mouse.y_pos) / scaling_hight; gem_image_state->u = 133.f + (x / 1.50f); gem_image_state->v = 160.f + (y / 1.67f); gem_image_state->projectionx = x - 320.f; gem_image_state->projectiony = 240.f - y; return true; } static bool mouse_pos_to_gem_state(const u32 mouse_no, vm::ptr<CellGemState>& gem_state) { const auto handler = g_fxo->get<MouseHandlerBase>(); std::scoped_lock lock(handler->mutex); if (!gem_state || mouse_no >= handler->GetMice().size()) { return false; } const auto& mouse = handler->GetMice().at(0); const auto renderer = static_cast<GSRender*>(rsx::get_current_renderer()); const auto width = renderer->get_frame()->client_width(); const auto hight = renderer->get_frame()->client_height(); const f32 scaling_width = width / 640.f; const f32 scaling_hight = hight / 480.f; const f32 x = static_cast<f32>(mouse.x_pos) / scaling_width; const f32 y = static_cast<f32>(mouse.y_pos) / scaling_hight; gem_state->pos[0] = x; gem_state->pos[1] = -y; gem_state->pos[2] = 1500.f; gem_state->pos[3] = 0.f; gem_state->quat[0] = 320.f - x; gem_state->quat[1] = (mouse.y_pos / scaling_width) - 180.f; gem_state->quat[2] = 1200.f; gem_state->handle_pos[0] = x; gem_state->handle_pos[1] = y; gem_state->handle_pos[2] = 1500.f; gem_state->handle_pos[3] = 0.f; return true; } // ********************* // * cellGem functions * // ********************* error_code cellGemCalibrate(u32 gem_num) { cellGem.todo("cellGemCalibrate(gem_num=%d)", gem_num); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (g_cfg.io.move == move_handler::fake || g_cfg.io.move == move_handler::mouse) { gem->controllers[gem_num].calibrated_magnetometer = true; gem->controllers[gem_num].enabled_tracking = true; gem->controllers[gem_num].hue = 1; gem->status_flags = CELL_GEM_FLAG_CALIBRATION_OCCURRED | CELL_GEM_FLAG_CALIBRATION_SUCCEEDED; } return CELL_OK; } error_code cellGemClearStatusFlags(u32 gem_num, u64 mask) { cellGem.todo("cellGemClearStatusFlags(gem_num=%d, mask=0x%x)", gem_num, mask); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } gem->status_flags &= ~mask; return CELL_OK; } error_code cellGemConvertVideoFinish() { cellGem.todo("cellGemConvertVideoFinish()"); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } return CELL_OK; } error_code cellGemConvertVideoStart(vm::cptr<void> video_frame) { cellGem.todo("cellGemConvertVideoStart(video_frame=*0x%x)", video_frame); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } return CELL_OK; } error_code cellGemEnableCameraPitchAngleCorrection(u32 enable_flag) { cellGem.todo("cellGemEnableCameraPitchAngleCorrection(enable_flag=%d)", enable_flag); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } gem->enable_pitch_correction = !!enable_flag; return CELL_OK; } error_code cellGemEnableMagnetometer(u32 gem_num, u32 enable) { cellGem.todo("cellGemEnableMagnetometer(gem_num=%d, enable=0x%x)", gem_num, enable); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!gem->is_controller_ready(gem_num)) { return CELL_GEM_NOT_CONNECTED; } gem->controllers[gem_num].enabled_magnetometer = !!enable; return CELL_OK; } error_code cellGemEnableMagnetometer2() { UNIMPLEMENTED_FUNC(cellGem); return CELL_OK; } error_code cellGemEnd(ppu_thread& ppu) { cellGem.warning("cellGemEnd()"); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (gem->state.compare_and_swap_test(1, 0)) { if (u32 addr = gem->memory_ptr) { sys_memory_free(ppu, addr); } return CELL_OK; } return CELL_GEM_ERROR_UNINITIALIZED; } error_code cellGemFilterState(u32 gem_num, u32 enable) { cellGem.warning("cellGemFilterState(gem_num=%d, enable=%d)", gem_num, enable); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } gem->controllers[gem_num].enabled_filtering = !!enable; return CELL_OK; } error_code cellGemForceRGB(u32 gem_num, float r, float g, float b) { cellGem.todo("cellGemForceRGB(gem_num=%d, r=%f, g=%f, b=%f)", gem_num, r, g, b); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } gem->controllers[gem_num].sphere_rgb = gem_config::gem_color(r, g, b); return CELL_OK; } error_code cellGemGetAccelerometerPositionInDevice() { UNIMPLEMENTED_FUNC(cellGem); return CELL_OK; } error_code cellGemGetAllTrackableHues(vm::ptr<u8> hues) { cellGem.todo("cellGemGetAllTrackableHues(hues=*0x%x)"); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } for (u32 i = 0; i < 360; i++) { hues[i] = true; } return CELL_OK; } error_code cellGemGetCameraState(vm::ptr<CellGemCameraState> camera_state) { cellGem.todo("cellGemGetCameraState(camera_state=0x%x)", camera_state); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!camera_state) { return CELL_GEM_ERROR_INVALID_PARAMETER; } camera_state->exposure_time = 1.0f / 60.0f; // TODO: use correct framerate camera_state->gain = 1.0; return CELL_OK; } error_code cellGemGetEnvironmentLightingColor(vm::ptr<f32> r, vm::ptr<f32> g, vm::ptr<f32> b) { cellGem.todo("cellGemGetEnvironmentLightingColor(r=*0x%x, g=*0x%x, b=*0x%x)", r, g, b); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!r || !g || !b) { return CELL_GEM_ERROR_INVALID_PARAMETER; } // default to 128 *r = 128; *g = 128; *b = 128; return CELL_OK; } error_code cellGemGetHuePixels(vm::cptr<void> camera_frame, u32 hue, vm::ptr<u8> pixels) { cellGem.todo("cellGemGetHuePixels(camera_frame=*0x%x, hue=%d, pixels=*0x%x)", camera_frame, hue, pixels); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!camera_frame || !pixels || hue > 359) { return CELL_GEM_ERROR_INVALID_PARAMETER; } return CELL_OK; } error_code cellGemGetImageState(u32 gem_num, vm::ptr<CellGemImageState> gem_image_state) { cellGem.todo("cellGemGetImageState(gem_num=%d, image_state=&0x%x)", gem_num, gem_image_state); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !gem_image_state) { return CELL_GEM_ERROR_INVALID_PARAMETER; } auto shared_data = g_fxo->get<gem_camera_shared>(); if (g_cfg.io.move == move_handler::fake) { gem_image_state->u = 0; gem_image_state->v = 0; gem_image_state->projectionx = 1; gem_image_state->projectiony = 1; } else if (g_cfg.io.move == move_handler::mouse) { mouse_pos_to_gem_image_state(gem_num, gem_image_state); } if (g_cfg.io.move == move_handler::fake || g_cfg.io.move == move_handler::mouse) { gem_image_state->frame_timestamp = shared_data->frame_timestamp.load(); gem_image_state->timestamp = gem_image_state->frame_timestamp + 10; gem_image_state->r = 10; gem_image_state->distance = 2 * 1000; // 2 meters away from camera gem_image_state->visible = true; gem_image_state->r_valid = true; } return CELL_OK; } error_code cellGemGetInertialState(u32 gem_num, u32 state_flag, u64 timestamp, vm::ptr<CellGemInertialState> inertial_state) { cellGem.warning("cellGemGetInertialState(gem_num=%d, state_flag=%d, timestamp=0x%x, inertial_state=0x%x)", gem_num, state_flag, timestamp, inertial_state); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || state_flag > CELL_GEM_INERTIAL_STATE_FLAG_NEXT || !inertial_state || !gem->is_controller_ready(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (g_cfg.io.move == move_handler::fake) { ds3_input_to_pad(gem_num, inertial_state->pad.digitalbuttons, inertial_state->pad.analog_T); } else if (g_cfg.io.move == move_handler::mouse) { mouse_input_to_pad(gem_num, inertial_state->pad.digitalbuttons, inertial_state->pad.analog_T); } if (g_cfg.io.move == move_handler::fake || g_cfg.io.move == move_handler::mouse) { ds3_input_to_ext(gem_num, inertial_state->ext); inertial_state->timestamp = gem->timer.GetElapsedTimeInMicroSec(); inertial_state->counter = gem->inertial_counter++; inertial_state->accelerometer[0] = 10; } return CELL_OK; } error_code cellGemGetInfo(vm::ptr<CellGemInfo> info) { cellGem.warning("cellGemGetInfo(info=*0x%x)", info); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!info) { return CELL_GEM_ERROR_INVALID_PARAMETER; } // TODO: Support connecting PlayStation Move controllers info->max_connect = gem->attribute.max_connect; info->now_connect = gem->connected_controllers; for (int i = 0; i < CELL_GEM_MAX_NUM; i++) { info->status[i] = gem->controllers[i].status; info->port[i] = gem->controllers[i].port; } return CELL_OK; } u32 GemGetMemorySize(s32 max_connect) { return max_connect <= 2 ? 0x120000 : 0x140000; } error_code cellGemGetMemorySize(s32 max_connect) { cellGem.warning("cellGemGetMemorySize(max_connect=%d)", max_connect); if (max_connect > CELL_GEM_MAX_NUM || max_connect <= 0) { return CELL_GEM_ERROR_INVALID_PARAMETER; } return not_an_error(GemGetMemorySize(max_connect)); } error_code cellGemGetRGB(u32 gem_num, vm::ptr<float> r, vm::ptr<float> g, vm::ptr<float> b) { cellGem.todo("cellGemGetRGB(gem_num=%d, r=*0x%x, g=*0x%x, b=*0x%x)", gem_num, r, g, b); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !r || !g || !b) { return CELL_GEM_ERROR_INVALID_PARAMETER; } auto& sphere_color = gem->controllers[gem_num].sphere_rgb; *r = sphere_color.r; *g = sphere_color.g; *b = sphere_color.b; return CELL_OK; } error_code cellGemGetRumble(u32 gem_num, vm::ptr<u8> rumble) { cellGem.todo("cellGemGetRumble(gem_num=%d, rumble=*0x%x)", gem_num, rumble); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !rumble) { return CELL_GEM_ERROR_INVALID_PARAMETER; } *rumble = gem->controllers[gem_num].rumble;<|fim▁hole|>error_code cellGemGetState(u32 gem_num, u32 flag, u64 time_parameter, vm::ptr<CellGemState> gem_state) { cellGem.warning("cellGemGetState(gem_num=%d, flag=0x%x, time=0x%llx, gem_state=*0x%x)", gem_num, flag, time_parameter, gem_state); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || flag > CELL_GEM_STATE_FLAG_TIMESTAMP || !gem_state) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (g_cfg.io.move == move_handler::fake) { ds3_input_to_pad(gem_num, gem_state->pad.digitalbuttons, gem_state->pad.analog_T); } else if (g_cfg.io.move == move_handler::mouse) { mouse_input_to_pad(gem_num, gem_state->pad.digitalbuttons, gem_state->pad.analog_T); mouse_pos_to_gem_state(gem_num, gem_state); } if (g_cfg.io.move == move_handler::fake || g_cfg.io.move == move_handler::mouse) { ds3_input_to_ext(gem_num, gem_state->ext); gem_state->tracking_flags = CELL_GEM_TRACKING_FLAG_POSITION_TRACKED | CELL_GEM_TRACKING_FLAG_VISIBLE; gem_state->timestamp = gem->timer.GetElapsedTimeInMicroSec(); gem_state->quat[3] = 1.f; return CELL_OK; } return CELL_GEM_NOT_CONNECTED; } error_code cellGemGetStatusFlags(u32 gem_num, vm::ptr<u64> flags) { cellGem.todo("cellGemGetStatusFlags(gem_num=%d, flags=*0x%x)", gem_num, flags); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !flags) { return CELL_GEM_ERROR_INVALID_PARAMETER; } *flags = gem->status_flags; return CELL_OK; } error_code cellGemGetTrackerHue(u32 gem_num, vm::ptr<u32> hue) { cellGem.warning("cellGemGetTrackerHue(gem_num=%d, hue=*0x%x)", gem_num, hue); const auto gem = g_fxo->get<gem_config>(); reader_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !hue) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (!gem->controllers[gem_num].enabled_tracking || gem->controllers[gem_num].hue > 359) { return CELL_GEM_ERROR_NOT_A_HUE; } *hue = gem->controllers[gem_num].hue; return CELL_OK; } error_code cellGemHSVtoRGB(f32 h, f32 s, f32 v, vm::ptr<f32> r, vm::ptr<f32> g, vm::ptr<f32> b) { cellGem.todo("cellGemHSVtoRGB(h=%f, s=%f, v=%f, r=*0x%x, g=*0x%x, b=*0x%x)", h, s, v, r, g, b); if (s < 0.0f || s > 1.0f || v < 0.0f || v > 1.0f || !r || !g || !b) { return CELL_GEM_ERROR_INVALID_PARAMETER; } h = std::clamp(h, 0.0f, 360.0f); // TODO: convert return CELL_OK; } error_code cellGemInit(ppu_thread& ppu, vm::cptr<CellGemAttribute> attribute) { cellGem.warning("cellGemInit(attribute=*0x%x)", attribute); const auto gem = g_fxo->get<gem_config>(); if (!attribute || !attribute->spurs_addr || !attribute->max_connect || attribute->max_connect > CELL_GEM_MAX_NUM) { return CELL_GEM_ERROR_INVALID_PARAMETER; } std::scoped_lock lock(gem->mtx); if (!gem->state.compare_and_swap_test(0, 1)) { return CELL_GEM_ERROR_ALREADY_INITIALIZED; } if (!attribute->memory_ptr) { vm::var<u32> addr(0); // Decrease memory stats if (sys_memory_allocate(ppu, GemGetMemorySize(attribute->max_connect), SYS_MEMORY_PAGE_SIZE_64K, +addr) != CELL_OK) { return CELL_GEM_ERROR_RESOURCE_ALLOCATION_FAILED; } gem->memory_ptr = *addr; } else { gem->memory_ptr = 0; } gem->update_started = false; gem->camera_frame = 0; gem->status_flags = 0; gem->attribute = *attribute; if (g_cfg.io.move == move_handler::mouse) { // init mouse handler const auto handler = g_fxo->get<MouseHandlerBase>(); handler->Init(std::min<u32>(attribute->max_connect, CELL_GEM_MAX_NUM)); } for (int gem_num = 0; gem_num < CELL_GEM_MAX_NUM; gem_num++) { gem->reset_controller(gem_num); } // TODO: is this correct? gem->timer.Start(); return CELL_OK; } error_code cellGemInvalidateCalibration(s32 gem_num) { cellGem.todo("cellGemInvalidateCalibration(gem_num=%d)", gem_num); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (g_cfg.io.move == move_handler::fake || g_cfg.io.move == move_handler::mouse) { gem->controllers[gem_num].calibrated_magnetometer = false; // TODO: gem->status_flags } return CELL_OK; } s32 cellGemIsTrackableHue(u32 hue) { cellGem.todo("cellGemIsTrackableHue(hue=%d)", hue); const auto gem = g_fxo->get<gem_config>(); if (!gem->state || hue > 359) { return false; } return true; } error_code cellGemPrepareCamera(s32 max_exposure, f32 image_quality) { cellGem.todo("cellGemPrepareCamera(max_exposure=%d, image_quality=%f)", max_exposure, image_quality); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } max_exposure = std::clamp(max_exposure, static_cast<s32>(CELL_GEM_MIN_CAMERA_EXPOSURE), static_cast<s32>(CELL_GEM_MAX_CAMERA_EXPOSURE)); image_quality = std::clamp(image_quality, 0.0f, 1.0f); // TODO: prepare camera return CELL_OK; } error_code cellGemPrepareVideoConvert(vm::cptr<CellGemVideoConvertAttribute> vc_attribute) { cellGem.todo("cellGemPrepareVideoConvert(vc_attribute=*0x%x)", vc_attribute); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!vc_attribute) { return CELL_GEM_ERROR_INVALID_PARAMETER; } const auto vc = *vc_attribute; if (!vc_attribute || vc.version == 0 || vc.output_format == 0 || (vc.conversion_flags & CELL_GEM_COMBINE_PREVIOUS_INPUT_FRAME && !vc.buffer_memory)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (vc.video_data_out & 0x1f || vc.buffer_memory & 0xff) { return CELL_GEM_ERROR_INVALID_ALIGNMENT; } gem->vc_attribute = vc; return CELL_OK; } error_code cellGemReadExternalPortDeviceInfo(u32 gem_num, vm::ptr<u32> ext_id, vm::ptr<u8[CELL_GEM_EXTERNAL_PORT_DEVICE_INFO_SIZE]> ext_info) { cellGem.todo("cellGemReadExternalPortDeviceInfo(gem_num=%d, ext_id=*0x%x, ext_info=%s)", gem_num, ext_id, ext_info); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num) || !ext_id) { return CELL_GEM_ERROR_INVALID_PARAMETER; } if (gem->controllers[gem_num].status & CELL_GEM_STATUS_DISCONNECTED) { return CELL_GEM_NOT_CONNECTED; } if (!(gem->controllers[gem_num].ext_status & CELL_GEM_EXT_CONNECTED)) { return CELL_GEM_NO_EXTERNAL_PORT_DEVICE; } return CELL_OK; } error_code cellGemReset(u32 gem_num) { cellGem.todo("cellGemReset(gem_num=%d)", gem_num); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } gem->reset_controller(gem_num); // TODO: is this correct? gem->timer.Start(); return CELL_OK; } error_code cellGemSetRumble(u32 gem_num, u8 rumble) { cellGem.todo("cellGemSetRumble(gem_num=%d, rumble=0x%x)", gem_num, rumble); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } gem->controllers[gem_num].rumble = rumble; return CELL_OK; } error_code cellGemSetYaw() { UNIMPLEMENTED_FUNC(cellGem); return CELL_OK; } error_code cellGemTrackHues(vm::cptr<u32> req_hues, vm::ptr<u32> res_hues) { cellGem.todo("cellGemTrackHues(req_hues=*0x%x, res_hues=*0x%x)", req_hues, res_hues); const auto gem = g_fxo->get<gem_config>(); std::scoped_lock lock(gem->mtx); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!req_hues) { return CELL_GEM_ERROR_INVALID_PARAMETER; } for (u32 i = 0; i < CELL_GEM_MAX_NUM; i++) { if (req_hues[i] == u32{CELL_GEM_DONT_CARE_HUE}) { } else if (req_hues[i] == u32{CELL_GEM_DONT_TRACK_HUE}) { gem->controllers[i].enabled_tracking = false; gem->controllers[i].enabled_LED = false; } else { if (req_hues[i] > 359) { cellGem.warning("cellGemTrackHues: req_hues[%d]=%d -> this can lead to unexpected behavior", i, req_hues[i]); } } } return CELL_OK; } error_code cellGemUpdateFinish() { cellGem.warning("cellGemUpdateFinish()"); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } std::scoped_lock lock(gem->mtx); if (!std::exchange(gem->update_started, false)) { return CELL_GEM_ERROR_UPDATE_NOT_STARTED; } if (!gem->camera_frame) { return not_an_error(CELL_GEM_NO_VIDEO); } return CELL_OK; } error_code cellGemUpdateStart(vm::cptr<void> camera_frame, u64 timestamp) { cellGem.warning("cellGemUpdateStart(camera_frame=*0x%x, timestamp=%d)", camera_frame, timestamp); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } std::scoped_lock lock(gem->mtx); // Update is starting even when camera_frame is null if (std::exchange(gem->update_started, true)) { return CELL_GEM_ERROR_UPDATE_NOT_FINISHED; } gem->camera_frame = camera_frame.addr(); if (!camera_frame) { return not_an_error(CELL_GEM_NO_VIDEO); } return CELL_OK; } error_code cellGemWriteExternalPort(u32 gem_num, vm::ptr<u8[CELL_GEM_EXTERNAL_PORT_OUTPUT_SIZE]> data) { cellGem.todo("cellGemWriteExternalPort(gem_num=%d, data=%s)", gem_num, data); const auto gem = g_fxo->get<gem_config>(); if (!gem->state) { return CELL_GEM_ERROR_UNINITIALIZED; } if (!check_gem_num(gem_num)) { return CELL_GEM_ERROR_INVALID_PARAMETER; } return CELL_OK; } DECLARE(ppu_module_manager::cellGem)("libgem", []() { REG_FUNC(libgem, cellGemCalibrate); REG_FUNC(libgem, cellGemClearStatusFlags); REG_FUNC(libgem, cellGemConvertVideoFinish); REG_FUNC(libgem, cellGemConvertVideoStart); REG_FUNC(libgem, cellGemEnableCameraPitchAngleCorrection); REG_FUNC(libgem, cellGemEnableMagnetometer); REG_FUNC(libgem, cellGemEnableMagnetometer2); REG_FUNC(libgem, cellGemEnd); REG_FUNC(libgem, cellGemFilterState); REG_FUNC(libgem, cellGemForceRGB); REG_FUNC(libgem, cellGemGetAccelerometerPositionInDevice); REG_FUNC(libgem, cellGemGetAllTrackableHues); REG_FUNC(libgem, cellGemGetCameraState); REG_FUNC(libgem, cellGemGetEnvironmentLightingColor); REG_FUNC(libgem, cellGemGetHuePixels); REG_FUNC(libgem, cellGemGetImageState); REG_FUNC(libgem, cellGemGetInertialState); REG_FUNC(libgem, cellGemGetInfo); REG_FUNC(libgem, cellGemGetMemorySize); REG_FUNC(libgem, cellGemGetRGB); REG_FUNC(libgem, cellGemGetRumble); REG_FUNC(libgem, cellGemGetState); REG_FUNC(libgem, cellGemGetStatusFlags); REG_FUNC(libgem, cellGemGetTrackerHue); REG_FUNC(libgem, cellGemHSVtoRGB); REG_FUNC(libgem, cellGemInit); REG_FUNC(libgem, cellGemInvalidateCalibration); REG_FUNC(libgem, cellGemIsTrackableHue); REG_FUNC(libgem, cellGemPrepareCamera); REG_FUNC(libgem, cellGemPrepareVideoConvert); REG_FUNC(libgem, cellGemReadExternalPortDeviceInfo); REG_FUNC(libgem, cellGemReset); REG_FUNC(libgem, cellGemSetRumble); REG_FUNC(libgem, cellGemSetYaw); REG_FUNC(libgem, cellGemTrackHues); REG_FUNC(libgem, cellGemUpdateFinish); REG_FUNC(libgem, cellGemUpdateStart); REG_FUNC(libgem, cellGemWriteExternalPort); });<|fim▁end|>
return CELL_OK; }
<|file_name|>app.ts<|end_file_name|><|fim▁begin|>import {server} from './initializers' <|fim▁hole|>}<|fim▁end|>
module.exports = function startServer(){ server.listen(8080)
<|file_name|>Clue.js<|end_file_name|><|fim▁begin|>import React from 'react'; import styled from 'styled-components'; import Item from './Item'; import parchment from '../assets/parchment.png'; import chest from '../assets/chest.png'; const Container = styled.div` background: url(${parchment}); position: relative; height: 286px; width: 303px; align-self: center; margin: 10px; `; const Items = styled.div` position: absolute; display: flex; flex-direction: row; flex-wrap: wrap; align-items: center; top: 78px; left: 130px; width: 108px; `; const Chest = styled.div` position: absolute; background: url(${chest}); image-rendering: pixelated; width: 92px; height: 92px; top: 138px; left: 34px; `; const Clue = ({ rewards, className, style }) => ( <Container className={className} style={style}> <Items><|fim▁hole|> <Item key={reward.id} id={reward.id} amount={reward.amount} /> ))} </Items> <Chest /> </Container> ); export default Clue;<|fim▁end|>
{rewards.map(reward => (
<|file_name|>cursor.py<|end_file_name|><|fim▁begin|>import asyncio import warnings import psycopg2 from .log import logger class Cursor: def __init__(self, conn, impl, timeout, echo): self._conn = conn self._impl = impl self._timeout = timeout self._echo = echo @property def echo(self): """Return echo mode status.""" return self._echo @property def description(self): """This read-only attribute is a sequence of 7-item sequences. Each of these sequences is a collections.namedtuple containing information describing one result column: 0. name: the name of the column returned. 1. type_code: the PostgreSQL OID of the column. 2. display_size: the actual length of the column in bytes. 3. internal_size: the size in bytes of the column associated to this column on the server. 4. precision: total number of significant digits in columns of type NUMERIC. None for other types. 5. scale: count of decimal digits in the fractional part in columns of type NUMERIC. None for other types. 6. null_ok: always None as not easy to retrieve from the libpq. This attribute will be None for operations that do not return rows or if the cursor has not had an operation invoked via the execute() method yet. """ return self._impl.description def close(self): """Close the cursor now.""" self._impl.close() @property def closed(self): """Read-only boolean attribute: specifies if the cursor is closed.""" return self._impl.closed @property def connection(self): """Read-only attribute returning a reference to the `Connection`.""" return self._conn @property def raw(self): """Underlying psycopg cursor object, readonly""" return self._impl @property def name(self): # Not supported return self._impl.name @property def scrollable(self): # Not supported return self._impl.scrollable @scrollable.setter def scrollable(self, val): # Not supported self._impl.scrollable = val @property def withhold(self): # Not supported return self._impl.withhold @withhold.setter def withhold(self, val): # Not supported self._impl.withhold = val @asyncio.coroutine def execute(self, operation, parameters=None, *, timeout=None): """Prepare and execute a database operation (query or command). Parameters may be provided as sequence or mapping and will be bound to variables in the operation. Variables are specified either with positional %s or named %({name})s placeholders. """ if timeout is None: timeout = self._timeout waiter = self._conn._create_waiter('cursor.execute') if self._echo: logger.info(operation) logger.info("%r", parameters) try: self._impl.execute(operation, parameters) except: self._conn._waiter = None raise else: yield from self._conn._poll(waiter, timeout) @asyncio.coroutine def executemany(self, operation, seq_of_parameters): # Not supported raise psycopg2.ProgrammingError( "executemany cannot be used in asynchronous mode") @asyncio.coroutine def callproc(self, procname, parameters=None, *, timeout=None): """Call a stored database procedure with the given name. The sequence of parameters must contain one entry for each argument that the procedure expects. The result of the call is returned as modified copy of the input sequence. Input parameters are left untouched, output and input/output parameters replaced with possibly new values. """ if timeout is None: timeout = self._timeout waiter = self._conn._create_waiter('cursor.callproc') if self._echo: logger.info("CALL %s", procname) logger.info("%r", parameters) try: self._impl.callproc(procname, parameters) except: self._conn._waiter = None raise else: yield from self._conn._poll(waiter, timeout) @asyncio.coroutine def mogrify(self, operation, parameters=None): """Return a query string after arguments binding. The string returned is exactly the one that would be sent to the database running the .execute() method or similar. """ ret = self._impl.mogrify(operation, parameters) assert not self._conn._isexecuting(), ("Don't support server side " "mogrify") return ret @asyncio.coroutine def setinputsizes(self, sizes): """This method is exposed in compliance with the DBAPI. It currently does nothing but it is safe to call it. """ self._impl.setinputsizes(sizes) @asyncio.coroutine def fetchone(self): """Fetch the next row of a query result set. Returns a single tuple, or None when no more data is available. """ ret = self._impl.fetchone() assert not self._conn._isexecuting(), ("Don't support server side " "cursors yet") return ret @asyncio.coroutine def fetchmany(self, size=None): """Fetch the next set of rows of a query result. Returns a list of tuples. An empty list is returned when no more rows are available. The number of rows to fetch per call is specified by the parameter. If it is not given, the cursor's .arraysize determines the number of rows to be fetched. The method should try to fetch as many rows as indicated by the size parameter. If this is not possible due to the specified number of rows not being available, fewer rows may be returned. """ if size is None: size = self._impl.arraysize ret = self._impl.fetchmany(size) assert not self._conn._isexecuting(), ("Don't support server side " "cursors yet") return ret @asyncio.coroutine def fetchall(self): """Fetch all (remaining) rows of a query result. Returns them as a list of tuples. An empty list is returned if there is no more record to fetch. """ ret = self._impl.fetchall() assert not self._conn._isexecuting(), ("Don't support server side " "cursors yet") return ret @asyncio.coroutine def scroll(self, value, mode="relative"): """Scroll to a new position according to mode. If mode is relative (default), value is taken as offset to the current position in the result set, if set to absolute, value states an absolute target position. """ ret = self._impl.scroll(value, mode) assert not self._conn._isexecuting(), ("Don't support server side " "cursors yet") return ret @property def arraysize(self): """How many rows will be returned by fetchmany() call. This read/write attribute specifies the number of rows to fetch at a time with fetchmany(). It defaults to 1 meaning to fetch a single row at a time. """ return self._impl.arraysize @arraysize.setter def arraysize(self, val): """How many rows will be returned by fetchmany() call. This read/write attribute specifies the number of rows to fetch at a time with fetchmany(). It defaults to 1 meaning to fetch a single row at a time. """ self._impl.arraysize = val @property def itersize(self): # Not supported return self._impl.itersize @itersize.setter def itersize(self, val): # Not supported self._impl.itersize = val @property def rowcount(self): """Returns the number of rows that has been produced of affected. This read-only attribute specifies the number of rows that the last :meth:`execute` produced (for Data Query Language statements like SELECT) or affected (for Data Manipulation Language statements like UPDATE or INSERT). The attribute is -1 in case no .execute() has been performed on the cursor or the row count of the last operation if it can't be determined by the interface. """ return self._impl.rowcount @property def rownumber(self): """Row index. This read-only attribute provides the current 0-based index of the cursor in the result set or ``None`` if the index cannot be determined.""" return self._impl.rownumber @property def lastrowid(self): """OID of the last inserted row. This read-only attribute provides the OID of the last row inserted by the cursor. If the table wasn't created with OID support or the last operation is not a single record insert, the attribute is set to None. """ return self._impl.lastrowid @property def query(self): """The last executed query string. Read-only attribute containing the body of the last query sent to the backend (including bound arguments) as bytes string. None if no query has been executed yet. """ return self._impl.query @property def statusmessage(self): """the message returned by the last command.""" return self._impl.statusmessage # @asyncio.coroutine # def cast(self, old, s): # ... @property def tzinfo_factory(self): """The time zone factory used to handle data types such as `TIMESTAMP WITH TIME ZONE`. """ return self._impl.tzinfo_factory @tzinfo_factory.setter def tzinfo_factory(self, val): """The time zone factory used to handle data types such as `TIMESTAMP WITH TIME ZONE`. """ self._impl.tzinfo_factory = val @asyncio.coroutine def nextset(self): # Not supported self._impl.nextset() # raises psycopg2.NotSupportedError @asyncio.coroutine def setoutputsize(self, size, column=None): # Does nothing self._impl.setoutputsize(size, column) @asyncio.coroutine def copy_from(self, file, table, sep='\t', null='\\N', size=8192, columns=None): raise psycopg2.ProgrammingError( "copy_from cannot be used in asynchronous mode") @asyncio.coroutine def copy_to(self, file, table, sep='\t', null='\\N', columns=None): raise psycopg2.ProgrammingError( "copy_to cannot be used in asynchronous mode") @asyncio.coroutine def copy_expert(self, sql, file, size=8192): raise psycopg2.ProgrammingError( "copy_expert cannot be used in asynchronous mode") @property def timeout(self): """Return default timeout for cursor operations.""" return self._timeout<|fim▁hole|> warnings.warn("Iteration over cursor is deprecated", DeprecationWarning, stacklevel=2) while True: row = yield from self.fetchone() if row is None: raise StopIteration else: yield row<|fim▁end|>
def __iter__(self):