com.amazonaws.auth.BasicAWSCredentials Scala Examples
The following examples show how to use com.amazonaws.auth.BasicAWSCredentials.
You can vote up the ones you like or vote down the ones you don't like,
and go to the original project or source file by following the links above each example.
Example 1
Source File: LambdaDeploymentAccount.scala From graphcool-framework with Apache License 2.0 | 5 votes |
package cool.graph.shared.functions.lambda import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.s3.{AmazonS3, AmazonS3ClientBuilder} import cool.graph.shared.models.Project import play.api.libs.json.Json import software.amazon.awssdk.auth.{AwsCredentials, StaticCredentialsProvider} import software.amazon.awssdk.regions.Region import software.amazon.awssdk.services.lambda.LambdaAsyncClient object LambdaDeploymentAccount { implicit val lambdaDeploymentBucket = Json.format[LambdaDeploymentBucket] implicit val lambdaDeploymentAccountFormat = Json.format[LambdaDeploymentAccount] } case class LambdaDeploymentAccount( id: String, accessKeyID: String, accessKey: String, deployIamArn: String, deploymentEnabled: Boolean, deploymentBuckets: Vector[LambdaDeploymentBucket] ) { lazy val credentialsProvider = new StaticCredentialsProvider(new AwsCredentials(accessKeyID, accessKey)) lazy val s3Credentials = new BasicAWSCredentials(accessKeyID, accessKey) def bucket(project: Project): String = { val region = getRegion(project.region.toString) deploymentBuckets.find(_.region == region).getOrElse(sys.error("Region is not supported for lambda deployment")).deploymentBucket } def lambdaClient(project: Project): LambdaAsyncClient = LambdaAsyncClient .builder() .region(Region.of(project.region.toString)) .credentialsProvider(credentialsProvider) .build() def s3Client(project: Project): AmazonS3 = { val region = getRegion(project.region.toString) AmazonS3ClientBuilder.standard .withCredentials(new AWSStaticCredentialsProvider(s3Credentials)) .withEndpointConfiguration(new EndpointConfiguration(s"s3-$region.amazonaws.com", region)) .build } private def getRegion(region: String) = Region.of(region).toString } case class LambdaDeploymentBucket(region: String, deploymentBucket: String)
Example 2
Source File: AWSAccounts.scala From sumobot with Apache License 2.0 | 5 votes |
package com.sumologic.sumobot.core.aws import com.amazonaws.auth.{AWSCredentials, BasicAWSCredentials} import com.sumologic.sumobot.core.config.ListOfConfigs import com.typesafe.config.Config object AWSAccounts { def load(config: Config): Map[String, AWSCredentials] = { ListOfConfigs.parse(config, "aws") { (name, accountConfig) => val key = accountConfig.getString(s"key.id") val secret = accountConfig.getString(s"key.secret") new BasicAWSCredentials(key, secret) } } }
Example 3
Source File: AwsConfig.scala From cave with MIT License | 5 votes |
package com.cave.metrics.data import com.amazonaws.auth.{AWSCredentials, AWSCredentialsProvider, BasicAWSCredentials, ClasspathPropertiesFileCredentialsProvider} import com.typesafe.config.Config trait AmazonWebServiceConfig { def endpoint: String def service: String def region: String } class AwsConfig(config: Config) { private lazy val awsConfig = config.resolve.getConfig("aws") private lazy val rdsConfig = awsConfig.resolve.getConfig("rds") private lazy val awsCredentialsConfig = awsConfig.getConfig("credentials") lazy val awsCredentialsProvider = createAwsCredentialsProvider( awsCredentialsConfig.getString("access-key"), awsCredentialsConfig.getString("secret-key")) println("AWS Access Key: " + awsCredentialsProvider.getCredentials.getAWSAccessKeyId) private lazy val kinesisConfig = awsConfig.getConfig("kinesis") lazy val awsKinesisConfig = makeAmazonWebServiceConfig(kinesisConfig) private lazy val awsKinesisStreamConfig = kinesisConfig.getConfig("stream") lazy val rawStreamName = awsKinesisStreamConfig.getString("raw") lazy val processedStreamName = awsKinesisStreamConfig.getString("processed") private lazy val sqsConfig = awsConfig.getConfig("sqs") lazy val awsSQSConfig = makeAmazonWebServiceConfig(sqsConfig) lazy val longPollTimeInSeconds = sqsConfig.getInt("longPollTimeInSeconds") private lazy val awsSqsQueuesConfig = sqsConfig.getConfig("queues") lazy val configurationChangesQueueName = awsSqsQueuesConfig.getString("config-changes") lazy val alarmScheduleQueueName = awsSqsQueuesConfig.getString("alarm-schedule") private lazy val autoScalingConfig = awsConfig.getConfig("autoscaling") lazy val awsAutoScalingConfig = makeAmazonWebServiceConfig(autoScalingConfig) private lazy val ec2Config = awsConfig.getConfig("ec2") lazy val awsEC2Config = makeAmazonWebServiceConfig(ec2Config) private lazy val snsConfig = awsConfig.getConfig("sns") lazy val awsSNSConfig = makeAmazonWebServiceConfig(snsConfig) private lazy val awsSnsTopicsConfig = snsConfig.getConfig("topics") lazy val configurationChangesTopicName = awsSnsTopicsConfig.getString("config-changes") lazy val rdsJdbcDatabaseClass = rdsConfig.getString("database-class") lazy val rdsJdbcDatabaseUrl = rdsConfig.getString("database-jdbc") lazy val rdsJdbcDatabaseServer = rdsConfig.getString("database-server") lazy val rdsJdbcDatabasePort = rdsConfig.getString("database-port") lazy val rdsJdbcDatabaseName = rdsConfig.getString("database-name") lazy val rdsJdbcDatabaseUser = rdsConfig.getString("database-user") lazy val rdsJdbcDatabasePassword = rdsConfig.getString("database-password") lazy val rdsJdbcDatabasePoolSize = rdsConfig.getInt("pool-size") lazy val rdsJdbcConnectionTimeout = rdsConfig.getInt("connection-timeout") lazy val leadershipTermTimeoutSeconds = config.getInt("leadershipTermTimeoutSeconds") lazy val leadershipTermLengthSeconds = config.getInt("leadershipTermLengthSeconds") private[this] def makeAmazonWebServiceConfig(config: Config) = new AmazonWebServiceConfig { override def endpoint: String = config.getString("endpoint") override def service: String = config.getString("service") override def region: String = config.getString("region") } }
Example 4
Source File: S3ConfigManager.scala From teamcity-s3-plugin with Apache License 2.0 | 5 votes |
package com.gu.teamcity import java.io.{File, PrintWriter} import com.amazonaws.auth.{BasicAWSCredentials, AWSCredentialsProvider, AWSCredentials} import jetbrains.buildServer.serverSide.ServerPaths import org.json4s._ import org.json4s.native.JsonMethods._ import org.json4s.native.Serialization import org.json4s.native.Serialization._ case class S3Config( artifactBucket: Option[String], buildManifestBucket: Option[String], tagManifestBucket: Option[String], awsAccessKey: Option[String], awsSecretKey: Option[String] ) class S3ConfigManager(paths: ServerPaths) extends AWSCredentialsProvider { implicit val formats = Serialization.formats(NoTypeHints) val configFile = new File(s"${paths.getConfigDir}/s3.json") private[teamcity] var config: Option[S3Config] = { if (configFile.exists()) { parse(configFile).extractOpt[S3Config] } else None } def artifactBucket: Option[String] = config.flatMap(_.artifactBucket) def buildManifestBucket: Option[String] = config.flatMap(_.buildManifestBucket) def tagManifestBucket: Option[String] = config.flatMap(_.tagManifestBucket) private[teamcity] def update(config: S3Config): Unit = { this.config = Some(if (config.awsSecretKey.isEmpty && config.awsAccessKey == this.config.flatMap(_.awsAccessKey)) { config.copy(awsSecretKey = this.config.flatMap(_.awsSecretKey)) } else config) } def updateAndPersist(newConfig: S3Config): Unit = { synchronized { update(newConfig) val out = new PrintWriter(configFile, "UTF-8") try { writePretty(config, out) } finally { out.close } } } def details: Map[String, Option[String]] = Map( "artifactBucket" -> artifactBucket, "buildManifestBucket" -> buildManifestBucket, "tagManifestBucket" -> tagManifestBucket, "accessKey" -> config.flatMap(_.awsAccessKey) ) override def getCredentials: AWSCredentials = (for { c <- config accessKey <- c.awsAccessKey secretKey <- c.awsSecretKey } yield new BasicAWSCredentials(accessKey, secretKey)).getOrElse(null) // Yes, this is sad override def refresh(): Unit = () } object S3ConfigManager { val bucketElement = "bucket" val s3Element = "S3" }
Example 5
Source File: AWSSigningJestClientFactory.scala From haystack-traces with Apache License 2.0 | 5 votes |
package com.expedia.www.haystack.trace.commons.clients.es import java.time.{LocalDateTime, ZoneId} import com.expedia.www.haystack.trace.commons.config.entities.AWSRequestSigningConfiguration import com.google.common.base.Supplier import io.searchbox.client.JestClientFactory import org.apache.http.impl.client.HttpClientBuilder import org.apache.http.impl.nio.client.HttpAsyncClientBuilder import org.slf4j.LoggerFactory import vc.inreach.aws.request.{AWSSigner, AWSSigningRequestInterceptor} import com.amazonaws.auth.AWSCredentialsProvider import com.amazonaws.auth.BasicAWSCredentials import com.amazonaws.auth.DefaultAWSCredentialsProviderChain import com.amazonaws.internal.StaticCredentialsProvider class AWSSigningJestClientFactory(awsRequestSigningConfig: AWSRequestSigningConfiguration) extends JestClientFactory { private val LOGGER = LoggerFactory.getLogger(classOf[AWSSigningJestClientFactory]) val awsSigner = new AWSSigner(getCredentialProvider, awsRequestSigningConfig.region, awsRequestSigningConfig.awsServiceName, new ClockSupplier) val requestInterceptor = new AWSSigningRequestInterceptor(awsSigner) override def configureHttpClient(builder: HttpClientBuilder): HttpClientBuilder = { builder.addInterceptorLast(requestInterceptor) } override def configureHttpClient(builder: HttpAsyncClientBuilder): HttpAsyncClientBuilder = { builder.addInterceptorLast(requestInterceptor) } def getCredentialProvider: AWSCredentialsProvider = { if (awsRequestSigningConfig.accessKey.isDefined) { LOGGER.info("using static aws credential provider with access and secret key for ES") new StaticCredentialsProvider( new BasicAWSCredentials(awsRequestSigningConfig.accessKey.get, awsRequestSigningConfig.secretKey.get)) } else { LOGGER.info("using default credential provider chain for ES") new DefaultAWSCredentialsProviderChain } } } class ClockSupplier extends Supplier[LocalDateTime] { override def get(): LocalDateTime = { LocalDateTime.now(ZoneId.of("UTC")) } }
Example 6
Source File: DynamoDBClient.scala From vinyldns with Apache License 2.0 | 5 votes |
package vinyldns.dynamodb.repository import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.dynamodbv2.{AmazonDynamoDBClient, AmazonDynamoDBClientBuilder} object DynamoDBClient { def apply(dynamoDBDataStoreSettings: DynamoDBDataStoreSettings): AmazonDynamoDBClient = { val dynamoAKID = dynamoDBDataStoreSettings.key val dynamoSecret = dynamoDBDataStoreSettings.secret val dynamoEndpoint = dynamoDBDataStoreSettings.endpoint val dynamoRegion = dynamoDBDataStoreSettings.region System.getProperties.setProperty("aws.accessKeyId", dynamoAKID) System.getProperties.setProperty("aws.secretKey", dynamoSecret) val credentials = new BasicAWSCredentials(dynamoAKID, dynamoSecret) AmazonDynamoDBClientBuilder .standard() .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(dynamoEndpoint, dynamoRegion)) .build() .asInstanceOf[AmazonDynamoDBClient] } }
Example 7
Source File: SqsMessageQueueProvider.scala From vinyldns with Apache License 2.0 | 5 votes |
package vinyldns.sqs.queue import cats.effect.IO import cats.implicits._ import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.sqs.model.QueueDoesNotExistException import com.amazonaws.services.sqs.{AmazonSQSAsync, AmazonSQSAsyncClientBuilder} import org.slf4j.LoggerFactory import pureconfig._ import pureconfig.generic.auto._ import pureconfig.module.catseffect.syntax._ import cats.effect.Blocker import vinyldns.core.queue.{MessageQueue, MessageQueueConfig, MessageQueueProvider} import scala.util.matching.Regex import cats.effect.ContextShift class SqsMessageQueueProvider extends MessageQueueProvider { import SqsMessageQueueProvider._ private implicit val cs: ContextShift[IO] = IO.contextShift(scala.concurrent.ExecutionContext.global) def load(config: MessageQueueConfig): IO[MessageQueue] = for { settingsConfig <- Blocker[IO].use( ConfigSource.fromConfig(config.settings).loadF[IO, SqsMessageQueueSettings](_) ) _ <- IO.fromEither(validateQueueName(settingsConfig.queueName)) client <- setupClient(settingsConfig) queueUrl <- setupQueue(client, settingsConfig.queueName) _ <- IO(logger.error(s"Queue URL: $queueUrl\n")) } yield new SqsMessageQueue(queueUrl, client) def validateQueueName(queueName: String): Either[InvalidQueueName, String] = { val validQueueNameRegex: Regex = """^([\w\-]{1,80})$""".r validQueueNameRegex .findFirstIn(queueName) .map(Right(_)) .getOrElse(Left(InvalidQueueName(queueName))) } def setupClient(sqsMessageQueueSettings: SqsMessageQueueSettings): IO[AmazonSQSAsync] = IO { logger.error( s"Setting up queue client with settings: " + s"service endpoint: ${sqsMessageQueueSettings.serviceEndpoint}; " + s"signing region: ${sqsMessageQueueSettings.serviceEndpoint}; " + s"queue name: ${sqsMessageQueueSettings.queueName}" ) AmazonSQSAsyncClientBuilder .standard() .withEndpointConfiguration( new EndpointConfiguration( sqsMessageQueueSettings.serviceEndpoint, sqsMessageQueueSettings.signingRegion ) ) .withCredentials( new AWSStaticCredentialsProvider( new BasicAWSCredentials( sqsMessageQueueSettings.accessKey, sqsMessageQueueSettings.secretKey ) ) ) .build() } def setupQueue(client: AmazonSQSAsync, queueName: String): IO[String] = // Create queue if it doesn't exist IO { logger.error(s"Setting up queue with name [$queueName]") client.getQueueUrl(queueName).getQueueUrl }.recoverWith { case _: QueueDoesNotExistException => IO(client.createQueue(queueName).getQueueUrl) } } object SqsMessageQueueProvider { final case class InvalidQueueName(queueName: String) extends Throwable( s"Invalid queue name: $queueName. Must be 1-80 alphanumeric, hyphen or underscore characters. FIFO queues " + "(queue names ending in \".fifo\") are not supported." ) private val logger = LoggerFactory.getLogger(classOf[SqsMessageQueueProvider]) }
Example 8
Source File: SnsNotifierProvider.scala From vinyldns with Apache License 2.0 | 5 votes |
package vinyldns.api.notifier.sns import vinyldns.core.notifier.{Notifier, NotifierConfig, NotifierProvider} import vinyldns.core.domain.membership.UserRepository import pureconfig._ import pureconfig.generic.auto._ import pureconfig.module.catseffect.syntax._ import cats.effect.{Blocker, ContextShift, IO} import com.amazonaws.services.sns.AmazonSNS import org.slf4j.LoggerFactory import com.amazonaws.services.sns.AmazonSNSClientBuilder import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.auth.AWSStaticCredentialsProvider import com.amazonaws.auth.BasicAWSCredentials class SnsNotifierProvider extends NotifierProvider { private implicit val cs: ContextShift[IO] = IO.contextShift(scala.concurrent.ExecutionContext.global) private val logger = LoggerFactory.getLogger(classOf[SnsNotifierProvider]) def load(config: NotifierConfig, userRepository: UserRepository): IO[Notifier] = for { snsConfig <- Blocker[IO].use( ConfigSource.fromConfig(config.settings).loadF[IO, SnsNotifierConfig](_) ) client <- createClient(snsConfig) } yield new SnsNotifier(snsConfig, client) def createClient(config: SnsNotifierConfig): IO[AmazonSNS] = IO { logger.error( "Setting up sns notifier client with settings: " + s"service endpoint: ${config.serviceEndpoint}; " + s"signing region: ${config.signingRegion}; " + s"topic name: ${config.topicArn}" ) AmazonSNSClientBuilder.standard .withEndpointConfiguration( new EndpointConfiguration(config.serviceEndpoint, config.signingRegion) ) .withCredentials( new AWSStaticCredentialsProvider( new BasicAWSCredentials(config.accessKey, config.secretKey) ) ) .build() } }
Example 9
Source File: SQSConsumer.scala From sqs-kafka-connect with Apache License 2.0 | 5 votes |
package com.hivehome.kafka.connect.sqs import javax.jms.{JMSException, MessageConsumer, Session} import com.amazon.sqs.javamessaging.SQSConnectionFactory import com.amazonaws.auth.{AWSCredentialsProviderChain, BasicAWSCredentials, DefaultAWSCredentialsProviderChain} import com.amazonaws.internal.StaticCredentialsProvider import com.amazonaws.regions.{Region, Regions} object SQSConsumer { def apply(conf: Conf): MessageConsumer = { val chain = buildCredentialsProviderChain(conf) createSQSConsumer(conf, chain) } @throws(classOf[JMSException]) private def createSQSConsumer(conf: Conf, chain: AWSCredentialsProviderChain): MessageConsumer = { val region = Regions.fromName(conf.awsRegion) val connectionFactory = SQSConnectionFactory.builder .withRegion(Region.getRegion(region)) .withAWSCredentialsProvider(chain) .build val connection = connectionFactory.createConnection val session = connection.createSession(false, Session.CLIENT_ACKNOWLEDGE) val queue = session.createQueue(conf.queueName.get) val consumer = session.createConsumer(queue) connection.start() consumer } private def buildCredentialsProviderChain(conf: Conf): AWSCredentialsProviderChain = { (conf.awsKey, conf.awsSecret) match { case (Some(key), Some(secret)) => val credentials = new BasicAWSCredentials(key, secret) new AWSCredentialsProviderChain(new StaticCredentialsProvider(credentials), new DefaultAWSCredentialsProviderChain) case _ => new DefaultAWSCredentialsProviderChain } } }
Example 10
Source File: DynamoDBContainerSpecSupport.scala From reactive-aws-clients with MIT License | 5 votes |
package com.github.j5ik2o.reactive.aws.dynamodb import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.regions.Regions import com.amazonaws.services.dynamodbv2.{ AmazonDynamoDB, AmazonDynamoDBClientBuilder } import com.github.j5ik2o.reactive.aws.test.RandomPortSupport import com.spotify.docker.client.{ DefaultDockerClient, DockerClient } import com.whisk.docker.impl.spotify.SpotifyDockerFactory import com.whisk.docker.scalatest.DockerTestKit import com.whisk.docker.{ DockerCommandExecutor, DockerContainer, DockerContainerState, DockerFactory, DockerReadyChecker } import org.scalatest.Suite import scala.concurrent.duration._ import scala.concurrent.{ ExecutionContext, Future } trait DynamoDBContainerSpecSupport extends DockerTestKit with RandomPortSupport { this: Suite => protected val connectTimeout: FiniteDuration = 3 seconds protected val readTimeout: FiniteDuration = 3 seconds protected val readyCheckInterval: FiniteDuration = 1 seconds protected val dockerClient: DockerClient = DefaultDockerClient .fromEnv() .connectTimeoutMillis(connectTimeout.toMillis) .readTimeoutMillis(readTimeout.toMillis).build() protected lazy val accessKeyId = "x" protected lazy val secretAccessKey = "x" protected lazy val endpoint = s"http://127.0.0.1:$dynamoDBPort" protected def dynamoDbClient: AmazonDynamoDB = AmazonDynamoDBClientBuilder .standard().withCredentials( new AWSStaticCredentialsProvider( new BasicAWSCredentials(accessKeyId, secretAccessKey) ) ).withEndpointConfiguration( new EndpointConfiguration(endpoint, Regions.AP_NORTHEAST_1.getName) ).build() override implicit def dockerFactory: DockerFactory = new SpotifyDockerFactory(dockerClient) protected class DynamoDBDockerReadyChecker(dynamoDbClient: AmazonDynamoDB) extends DockerReadyChecker { override def apply(container: DockerContainerState)( implicit docker: DockerCommandExecutor, ec: ExecutionContext ): Future[Boolean] = Future.successful { try { dynamoDbClient.listTables(1) Thread.sleep(readyCheckInterval.toMillis) true } catch { case _: Exception => Thread.sleep(readyCheckInterval.toMillis) false } } } protected lazy val dynamoDBPort: Int = temporaryServerPort() protected lazy val dynamoDBContainer: DockerContainer = DockerContainer("amazon/dynamodb-local:1.12.0") .withPorts(8000 -> Some(dynamoDBPort)) .withReadyChecker(new DynamoDBDockerReadyChecker(dynamoDbClient)) abstract override def dockerContainers: List[DockerContainer] = dynamoDBContainer :: super.dockerContainers }
Example 11
Source File: DynamoDBEmbeddedSpecSupport.scala From reactive-aws-clients with MIT License | 5 votes |
package com.github.j5ik2o.reactive.aws.dynamodb import java.io.File import java.util.logging.{ Level, Logger } import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.regions.Regions import com.amazonaws.services.dynamodbv2.local.server.{ DynamoDBProxyServer, LocalDynamoDBRequestHandler, LocalDynamoDBServerHandler } import com.amazonaws.services.dynamodbv2.{ AmazonDynamoDB, AmazonDynamoDBClientBuilder } import com.github.j5ik2o.reactive.aws.test.RandomPortSupport import org.scalatest.{ BeforeAndAfterAll, Suite } import org.seasar.util.io.ResourceUtil import scala.concurrent.duration._ @SuppressWarnings(Array("org.wartremover.warts.Null", "org.wartremover.warts.Var", "org.wartremover.warts.While")) trait DynamoDBEmbeddedSpecSupport extends BeforeAndAfterAll with RandomPortSupport { this: Suite => protected val waitIntervalForDynamoDBLocal: FiniteDuration = 500 milliseconds protected def sqlite4javaLibraryPath: File = new File(ResourceUtil.getBuildDir(getClass), "/../../../native-libs") protected val region: Regions = Regions.AP_NORTHEAST_1 protected lazy val accessKeyId: String = "x" protected lazy val secretAccessKey: String = "x" protected lazy val dynamoDBPort: Int = temporaryServerPort() protected lazy val dynamoDBEndpoint: String = s"http://127.0.0.1:$dynamoDBPort" protected lazy val dynamoDBProxyServer: DynamoDBProxyServer = { System.setProperty("sqlite4java.library.path", sqlite4javaLibraryPath.toString) val inMemory = true // scalastyle:off val dbPath = null val sharedDb = false val corsParams = null // scalastyle:on new DynamoDBProxyServer( dynamoDBPort, new LocalDynamoDBServerHandler( new LocalDynamoDBRequestHandler(0, inMemory, dbPath, sharedDb, false), corsParams ) ) } protected lazy val dynamoDBClient: AmazonDynamoDB = { AmazonDynamoDBClientBuilder .standard().withCredentials( new AWSStaticCredentialsProvider( new BasicAWSCredentials(accessKeyId, secretAccessKey) ) ) .withEndpointConfiguration( new EndpointConfiguration(dynamoDBEndpoint, region.getName) ).build() } protected def waitDynamoDBLocal(): Unit = { var isWaken: Boolean = false while (!isWaken) { try { dynamoDBClient.listTables() isWaken = true } catch { case _: Exception => Thread.sleep(waitIntervalForDynamoDBLocal.toMillis) } } } protected def startDynamoDBLocal(): Unit = { Logger.getLogger("com.almworks.sqlite4java").setLevel(Level.OFF) dynamoDBProxyServer.start() } protected def shutdownDynamoDBLocal(): Unit = { dynamoDBProxyServer.stop() } override protected def beforeAll(): Unit = { super.beforeAll() startDynamoDBLocal() waitDynamoDBLocal() } override protected def afterAll(): Unit = { shutdownDynamoDBLocal() super.afterAll() } }
Example 12
Source File: AwsInitializers.scala From graphcool-framework with Apache License 2.0 | 5 votes |
package cool.graph.aws import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.kinesis.{AmazonKinesis, AmazonKinesisClientBuilder} import com.amazonaws.services.s3.{AmazonS3, AmazonS3ClientBuilder} import com.amazonaws.services.sns.{AmazonSNS, AmazonSNSAsyncClientBuilder} object AwsInitializers { lazy val accessKeyId = sys.env.getOrElse("AWS_ACCESS_KEY_ID", "") lazy val accessKey = sys.env.getOrElse("AWS_SECRET_ACCESS_KEY", "") lazy val credentials = new BasicAWSCredentials(accessKeyId, accessKey) def createKinesis(): AmazonKinesis = { AmazonKinesisClientBuilder .standard() .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(sys.env("KINESIS_ENDPOINT"), sys.env("AWS_REGION"))) .build() } def createSns(): AmazonSNS = { AmazonSNSAsyncClientBuilder.standard .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(sys.env("SNS_ENDPOINT"), sys.env("AWS_REGION"))) .build } def createS3(): AmazonS3 = { AmazonS3ClientBuilder.standard .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(sys.env("FILEUPLOAD_S3_ENDPOINT"), sys.env("AWS_REGION"))) .build } def createExportDataS3(): AmazonS3 = { AmazonS3ClientBuilder.standard .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(sys.env("DATA_EXPORT_S3_ENDPOINT"), sys.env("AWS_REGION"))) .build } // This is still in the old SBS AWS account def createS3Fileupload(): AmazonS3 = { val credentials = new BasicAWSCredentials( sys.env("FILEUPLOAD_S3_AWS_ACCESS_KEY_ID"), sys.env("FILEUPLOAD_S3_AWS_SECRET_ACCESS_KEY") ) AmazonS3ClientBuilder.standard .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(new EndpointConfiguration(sys.env("FILEUPLOAD_S3_ENDPOINT"), sys.env("AWS_REGION"))) .build } }
Example 13
Source File: V1DynamoDBClientBuilderUtils.scala From akka-persistence-dynamodb with Apache License 2.0 | 5 votes |
package com.github.j5ik2o.akka.persistence.dynamodb.utils import akka.actor.DynamicAccess import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.dynamodbv2.{ AmazonDynamoDBAsyncClientBuilder, AmazonDynamoDBClientBuilder } import com.github.j5ik2o.akka.persistence.dynamodb.client.v1.{ MonitoringListenerProvider, RequestHandlersProvider, RequestMetricCollectorProvider } import com.github.j5ik2o.akka.persistence.dynamodb.config.PluginConfig object V1DynamoDBClientBuilderUtils { def setupSync(dynamicAccess: DynamicAccess, pluginConfig: PluginConfig): AmazonDynamoDBClientBuilder = { val cc = V1ClientConfigurationUtils.setup(dynamicAccess, pluginConfig) val monitoringListenerProvider = MonitoringListenerProvider.create(dynamicAccess, pluginConfig) val requestHandlersProvider = RequestHandlersProvider.create(dynamicAccess, pluginConfig) val requestMetricCollectorProvider = RequestMetricCollectorProvider.create(dynamicAccess, pluginConfig) val builder = AmazonDynamoDBClientBuilder .standard().withClientConfiguration(cc) // builder.setClientSideMonitoringConfigurationProvider() monitoringListenerProvider.create.foreach { m => builder.setMonitoringListener(m) } builder.setRequestHandlers(requestHandlersProvider.create: _*) requestMetricCollectorProvider.create.foreach { r => builder.setMetricsCollector(r) } (pluginConfig.clientConfig.accessKeyId, pluginConfig.clientConfig.secretAccessKey) match { case (Some(a), Some(s)) => builder.setCredentials( new AWSStaticCredentialsProvider(new BasicAWSCredentials(a, s)) ) case _ => } (pluginConfig.clientConfig.region, pluginConfig.clientConfig.endpoint) match { case (Some(r), Some(e)) => builder.setEndpointConfiguration(new EndpointConfiguration(e, r)) case (Some(r), _) => builder.setRegion(r) case _ => } builder } def setupAsync(dynamicAccess: DynamicAccess, pluginConfig: PluginConfig): AmazonDynamoDBAsyncClientBuilder = { val cc = V1ClientConfigurationUtils.setup(dynamicAccess, pluginConfig) val builder = AmazonDynamoDBAsyncClientBuilder.standard().withClientConfiguration(cc) (pluginConfig.clientConfig.accessKeyId, pluginConfig.clientConfig.secretAccessKey) match { case (Some(a), Some(s)) => builder.setCredentials( new AWSStaticCredentialsProvider(new BasicAWSCredentials(a, s)) ) case _ => } (pluginConfig.clientConfig.region, pluginConfig.clientConfig.endpoint) match { case (Some(r), Some(e)) => builder.setEndpointConfiguration(new EndpointConfiguration(e, r)) case (Some(r), _) => builder.setRegion(r) case _ => } builder } }
Example 14
Source File: FileManagerS3Mock.scala From HAT2.0 with GNU Affero General Public License v3.0 | 5 votes |
package org.hatdex.hat.api.service import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.services.s3.model.ObjectMetadata import com.amazonaws.services.s3.{ AmazonS3, AmazonS3ClientBuilder } import org.specs2.mock.Mockito import scala.concurrent.duration._ case class FileManagerS3Mock() extends Mockito { val s3Configuration = AwsS3Configuration("hat-storage-test", "testAwsAccessKey", "testAwsSecret", "eu-west-1", 5.minutes) private val awsCreds: BasicAWSCredentials = new BasicAWSCredentials(s3Configuration.accessKeyId, s3Configuration.secretKey) val mockS3client: AmazonS3 = spy(AmazonS3ClientBuilder.standard() .withRegion("eu-west-1") .withCredentials(new AWSStaticCredentialsProvider(awsCreds)) .build()) private val s3ObjectMetadata = new ObjectMetadata() s3ObjectMetadata.setContentLength(123456L) doReturn(s3ObjectMetadata).when(mockS3client).getObjectMetadata("hat-storage-test", "hat.hubofallthings.net/testFile") doNothing.when(mockS3client).deleteObject("hat-storage-test", "hat.hubofallthings.net/deleteFile") }
Example 15
Source File: FileManagerModule.scala From HAT2.0 with GNU Affero General Public License v3.0 | 5 votes |
package org.hatdex.hat.modules import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.services.s3.{ AmazonS3, AmazonS3ClientBuilder } import com.google.inject.name.Named import com.google.inject.{ AbstractModule, Provides } import net.codingwell.scalaguice.ScalaModule import org.hatdex.hat.api.service.{ AwsS3Configuration, FileManager, FileManagerS3 } import play.api.Configuration import play.api.libs.concurrent.AkkaGuiceSupport class FileManagerModule extends AbstractModule with ScalaModule with AkkaGuiceSupport { override def configure() = { bind[FileManager].to[FileManagerS3] () } @Provides def provideCookieAuthenticatorService(configuration: Configuration): AwsS3Configuration = { import AwsS3Configuration.configLoader configuration.get[AwsS3Configuration]("storage.s3Configuration") } @Provides @Named("s3client-file-manager") def provides3Client(configuration: AwsS3Configuration): AmazonS3 = { val awsCreds: BasicAWSCredentials = new BasicAWSCredentials(configuration.accessKeyId, configuration.secretKey) AmazonS3ClientBuilder.standard() .withRegion(configuration.region) .withCredentials(new AWSStaticCredentialsProvider(awsCreds)) .build() } }
Example 16
Source File: S3Sandbox.scala From redshift-fake-driver with Apache License 2.0 | 5 votes |
package jp.ne.opt.redshiftfake import java.net.URI import com.amazonaws.auth.{AWSCredentials, BasicAWSCredentials} import com.amazonaws.regions.RegionUtils import com.amazonaws.services.s3.AmazonS3Client import org.gaul.s3proxy.{AuthenticationType, S3Proxy} import org.jclouds.ContextBuilder import org.jclouds.blobstore.BlobStoreContext import org.scalatest.{BeforeAndAfterAll, Suite} trait S3Sandbox extends BeforeAndAfterAll {this: Suite => val dummyCredentials: Credentials.WithKey val s3Endpoint: String var s3Proxy: S3Proxy = _ override def beforeAll(): Unit = { val blobContext: BlobStoreContext = ContextBuilder .newBuilder("transient") .build(classOf[BlobStoreContext]) s3Proxy = S3Proxy.builder .blobStore(blobContext.getBlobStore) .awsAuthentication(AuthenticationType.AWS_V4, dummyCredentials.accessKeyId, dummyCredentials.secretAccessKey) .endpoint(URI.create(s3Endpoint)) .build s3Proxy.start() } override def afterAll(): Unit = { s3Proxy.stop() } def createS3Client(s3Region: String): AmazonS3Client = { val credentials: AWSCredentials = new BasicAWSCredentials(dummyCredentials.accessKeyId, dummyCredentials.secretAccessKey) val client = new AmazonS3Client(credentials) client.setRegion(RegionUtils.getRegion(s3Region)) client.setEndpoint(s3Endpoint) client } }
Example 17
Source File: S3Minio.scala From openwhisk with Apache License 2.0 | 5 votes |
package org.apache.openwhisk.core.database.s3 import java.net.ServerSocket import actionContainers.ActionContainer import akka.actor.ActorSystem import akka.stream.ActorMaterializer import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.services.s3.AmazonS3ClientBuilder import com.typesafe.config.ConfigFactory import common.{SimpleExec, StreamLogging} import org.scalatest.{BeforeAndAfterAll, FlatSpec} import org.apache.openwhisk.common.{Logging, TransactionId} import org.apache.openwhisk.core.database.{AttachmentStore, DocumentSerializer} import scala.concurrent.duration._ import scala.reflect.ClassTag trait S3Minio extends FlatSpec with BeforeAndAfterAll with StreamLogging { def makeS3Store[D <: DocumentSerializer: ClassTag]()(implicit actorSystem: ActorSystem, logging: Logging, materializer: ActorMaterializer): AttachmentStore = { val config = ConfigFactory.parseString(s""" |whisk { | s3 { | alpakka { | aws { | credentials { | provider = static | access-key-id = "$accessKey" | secret-access-key = "$secretAccessKey" | } | region { | provider = static | default-region = us-west-2 | } | } | endpoint-url = "http://localhost:$port" | } | bucket = "$bucket" | $prefixConfig | } |} """.stripMargin).withFallback(ConfigFactory.load()) S3AttachmentStoreProvider.makeStore[D](config) } private val accessKey = "TESTKEY" private val secretAccessKey = "TESTSECRET" private val port = freePort() private val bucket = "test-ow-travis" private def prefixConfig = { if (bucketPrefix.nonEmpty) s"prefix = $bucketPrefix" else "" } protected def bucketPrefix: String = "" override protected def beforeAll(): Unit = { super.beforeAll() dockerExec( s"run -d -e MINIO_ACCESS_KEY=$accessKey -e MINIO_SECRET_KEY=$secretAccessKey -p $port:9000 minio/minio server /data") println(s"Started minio on $port") createTestBucket() } override def afterAll(): Unit = { super.afterAll() val containerId = dockerExec("ps -q --filter ancestor=minio/minio") containerId.split("\n").map(_.trim).foreach(id => dockerExec(s"stop $id")) println(s"Stopped minio container") } def createTestBucket(): Unit = { val endpoint = new EndpointConfiguration(s"http://localhost:$port", "us-west-2") val client = AmazonS3ClientBuilder.standard .withPathStyleAccessEnabled(true) .withEndpointConfiguration(endpoint) .withCredentials(new AWSStaticCredentialsProvider(new BasicAWSCredentials(accessKey, secretAccessKey))) .build org.apache.openwhisk.utils.retry(client.createBucket(bucket), 6, Some(1.minute)) println(s"Created bucket $bucket") } private def dockerExec(cmd: String): String = { implicit val tid: TransactionId = TransactionId.testing val command = s"${ActionContainer.dockerCmd} $cmd" val cmdSeq = command.split(" ").map(_.trim).filter(_.nonEmpty) val (out, err, code) = SimpleExec.syncRunCmd(cmdSeq) assert(code == 0, s"Error occurred for command '$command'. Exit code: $code, Error: $err") out } private def freePort(): Int = { val socket = new ServerSocket(0) try socket.getLocalPort finally if (socket != null) socket.close() } }
Example 18
Source File: S3Client.scala From akka-persistence-s3 with MIT License | 5 votes |
package akka.persistence.s3 import java.io.InputStream import com.amazonaws.auth.{ BasicAWSCredentials, DefaultAWSCredentialsProviderChain } import com.amazonaws.services.s3.{ S3ClientOptions, AmazonS3Client } import com.amazonaws.services.s3.model._ import scala.concurrent.{ Future, ExecutionContext } trait S3Client { val s3ClientConfig: S3ClientConfig lazy val client: AmazonS3Client = { val client = if (s3ClientConfig.awsUseDefaultCredentialsProviderChain) new AmazonS3Client(new DefaultAWSCredentialsProviderChain).withRegion(s3ClientConfig.region) else new AmazonS3Client(new BasicAWSCredentials(s3ClientConfig.awsKey, s3ClientConfig.awsSecret)) s3ClientConfig.endpoint.foreach { endpoint => client.withEndpoint(endpoint) () } client.setS3ClientOptions(new S3ClientOptions() .withPathStyleAccess(s3ClientConfig.options.pathStyleAccess) .withChunkedEncodingDisabled(s3ClientConfig.options.chunkedEncodingDisabled)) client } def createBucket(bucketName: String)(implicit ec: ExecutionContext): Future[Bucket] = Future { client.createBucket(bucketName) } def deleteBucket(bucketName: String)(implicit ec: ExecutionContext): Future[Unit] = Future { client.deleteBucket(bucketName) } def putObject(bucketName: String, key: String, input: InputStream, metadata: ObjectMetadata)(implicit ec: ExecutionContext): Future[PutObjectResult] = Future { client.putObject(new PutObjectRequest(bucketName, key, input, metadata)) } def getObject(bucketName: String, key: String)(implicit ec: ExecutionContext): Future[S3Object] = Future { client.getObject(new GetObjectRequest(bucketName, key)) } def listObjects(request: ListObjectsRequest)(implicit ec: ExecutionContext): Future[ObjectListing] = Future { client.listObjects(request) } def deleteObject(bucketName: String, key: String)(implicit ec: ExecutionContext): Future[Unit] = Future { client.deleteObject(bucketName, key) } def deleteObjects(request: DeleteObjectsRequest)(implicit ec: ExecutionContext): Future[Unit] = Future { client.deleteObjects(request) } }
Example 19
Source File: StsSdkHelpers.scala From rokku with Apache License 2.0 | 5 votes |
package com.ing.wbaa.testkit.awssdk import akka.http.scaladsl.model.Uri import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder.EndpointConfiguration import com.amazonaws.regions.Regions import com.amazonaws.services.securitytoken.{AWSSecurityTokenService, AWSSecurityTokenServiceClientBuilder} trait StsSdkHelpers { def getAmazonSTSSdk(uri: Uri): AWSSecurityTokenService = { AWSSecurityTokenServiceClientBuilder .standard() .withCredentials(new AWSStaticCredentialsProvider(new BasicAWSCredentials("accesskey", "secretkey"))) .withEndpointConfiguration(new EndpointConfiguration( s"${uri.scheme}://${uri.authority.host.address}:${uri.authority.port}", Regions.DEFAULT_REGION.getName) ) .build() } }
Example 20
Source File: S3Client.scala From rokku with Apache License 2.0 | 5 votes |
package com.ing.wbaa.rokku.proxy.provider.aws import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.client.builder.AwsClientBuilder import com.amazonaws.regions.Regions import com.amazonaws.services.s3.model.{ AccessControlList, BucketPolicy, GroupGrantee, Permission } import com.amazonaws.services.s3.{ AmazonS3, AmazonS3ClientBuilder } import com.ing.wbaa.rokku.proxy.config.StorageS3Settings import com.ing.wbaa.rokku.proxy.data.RequestId import com.ing.wbaa.rokku.proxy.handler.LoggerHandlerWithId import scala.concurrent.{ ExecutionContext, Future } import scala.util.{ Failure, Success, Try } trait S3Client { protected[this] implicit def executionContext: ExecutionContext private val logger = new LoggerHandlerWithId protected[this] def storageS3Settings: StorageS3Settings protected[this] lazy val s3Client: AmazonS3 = { val credentials = new BasicAWSCredentials( storageS3Settings.storageS3AdminAccesskey, storageS3Settings.storageS3AdminSecretkey) val endpointConfiguration = new AwsClientBuilder.EndpointConfiguration( s"http://${storageS3Settings.storageS3Authority.host.address()}:${storageS3Settings.storageS3Authority.port}", Regions.US_EAST_1.getName) AmazonS3ClientBuilder.standard() .withPathStyleAccessEnabled(true) .withCredentials(new AWSStaticCredentialsProvider(credentials)) .withEndpointConfiguration(endpointConfiguration) .build() } protected[this] def setDefaultBucketAclAndPolicy(bucketName: String)(implicit id: RequestId): Future[Unit] = Future { Try { logger.info("setting bucket acls and policies for bucket {}", bucketName) val acl = s3Client.getBucketAcl(bucketName) acl.revokeAllPermissions(GroupGrantee.AuthenticatedUsers) acl.grantPermission(GroupGrantee.AuthenticatedUsers, Permission.Read) acl.grantPermission(GroupGrantee.AuthenticatedUsers, Permission.Write) s3Client.setBucketAcl(bucketName, acl) s3Client.setBucketPolicy(bucketName, """{"Statement": [{"Action": ["s3:GetObject"],"Effect": "Allow","Principal": "*","Resource": ["arn:aws:s3:::*"]}],"Version": "2012-10-17"}""") } match { case Failure(exception) => logger.error("setting bucket acls and policies ex={}", exception.getMessage) case Success(_) => logger.info("acls and policies for bucket {} done", bucketName) } } def getBucketAcl(bucketName: String): Future[AccessControlList] = Future { s3Client.getBucketAcl(bucketName) } def getBucketPolicy(bucketName: String): Future[BucketPolicy] = Future { s3Client.getBucketPolicy(bucketName) } def listBucket: String = { s3Client.listObjects(storageS3Settings.bucketName).getBucketName } }
Example 21
Source File: SignatureHelpersV4.scala From rokku with Apache License 2.0 | 5 votes |
package com.ing.wbaa.rokku.proxy.provider.aws import java.util import akka.http.scaladsl.model.HttpRequest import com.amazonaws.DefaultRequest import com.amazonaws.auth.BasicAWSCredentials import com.amazonaws.util.DateUtils import com.ing.wbaa.rokku.proxy.provider.aws.SignatureHelpersCommon.extractHeaderOption import com.ing.wbaa.rokku.proxy.data import com.ing.wbaa.rokku.proxy.data.{ AWSHeaderValues, RequestId } import com.ing.wbaa.rokku.proxy.handler.LoggerHandlerWithId import scala.collection.JavaConverters._ class SignatureHelpersV4 extends SignatureHelpersCommon { private val logger = new LoggerHandlerWithId private def fixHeaderCapitals(header: String): String = { header.split("-").map { h => h(0).toUpper + h.substring(1).toLowerCase }.mkString("-") } // java Map[String, util.List[String]] is need by AWS4Signer def extractRequestParameters(httpRequest: HttpRequest): util.Map[String, util.List[String]] = { val rawQueryString = httpRequest.uri.rawQueryString.getOrElse("") if (rawQueryString.length > 1) { rawQueryString match { // for aws subresource ?acl etc. case queryString if queryString.length > 1 && !queryString.contains("=") => // aws uses subresource= during signature generation, so we add empty string to list - /demobucket/?acl=" Map(queryString -> List[String]("").asJava).asJava // single param=value case queryString if queryString.contains("=") && !queryString.contains("&") => splitQueryToJavaMap(queryString) // multiple param=value case queryString if queryString.contains("&") => splitQueryToJavaMap(queryString) case _ => Map[String, java.util.List[String]]().empty.asJava } } else { Map[String, java.util.List[String]]().empty.asJava } } def getSignedHeaders(authorization: String): String = """\S+ SignedHeaders=(\S+), """.r .findFirstMatchIn(authorization) .map(_ group 1).getOrElse("") def getAWSHeaders(httpRequest: HttpRequest): AWSHeaderValues = { implicit val hr = httpRequest val authorization: Option[String] = extractHeaderOption("authorization") val signature = authorization.map(auth => getSignatureFromAuthorization(auth)) val accessKey = authorization.map(auth => getCredentialFromAuthorization(auth)) val signedHeadersMap = authorization.map(auth => getSignedHeaders(auth)).getOrElse("") .split(";") .toList .map { header => if (header == "content-type") { (fixHeaderCapitals(header), httpRequest.entity.contentType.mediaType.value) } else if (header == "content-length") { val contentLength = httpRequest.entity.getContentLengthOption().orElse(0L) (fixHeaderCapitals(header), contentLength.toString) } else if (header == "amz-sdk-invocation-id" || header == "amz-sdk-retry") { (header, extractHeaderOption(header).getOrElse("")) } else if (header == "x-amz-content-sha256") { ("X-Amz-Content-SHA256", extractHeaderOption(header).getOrElse("")) } else { (fixHeaderCapitals(header), extractHeaderOption(header).getOrElse("")) } }.toMap data.AWSHeaderValues(accessKey, signedHeadersMap, signature, None, None, None) } // for now we do not have any regions, we use default one def signS3Request(request: DefaultRequest[_], credentials: BasicAWSCredentials, date: String, region: String = "us-east-1")(implicit id: RequestId): Unit = { logger.debug("Using version 4 signer") val signer = new CustomV4Signer() signer.setRegionName(region) signer.setServiceName(request.getServiceName) signer.setOverrideDate(DateUtils.parseCompressedISO8601Date(date)) signer.sign(request, credentials) } // add headers from original request before sign def addHeadersToRequest(request: DefaultRequest[_], awsHeaders: AWSHeaderValues, mediaType: String): Unit = awsHeaders.signedHeadersMap.foreach(p => request.addHeader(p._1, p._2)) }
Example 22
Source File: S3StoreTest.scala From fs2-blobstore with Apache License 2.0 | 5 votes |
package blobstore package s3 import cats.effect.IO import com.amazonaws.ClientConfiguration import com.amazonaws.auth.{AWSStaticCredentialsProvider, BasicAWSCredentials} import com.amazonaws.client.builder.AwsClientBuilder import com.amazonaws.regions.Regions import com.amazonaws.services.s3.transfer.{TransferManager, TransferManagerBuilder} import com.amazonaws.services.s3.{AmazonS3, AmazonS3ClientBuilder} class S3StoreTest extends AbstractStoreTest { val credentials = new BasicAWSCredentials("my_access_key", "my_secret_key") val clientConfiguration = new ClientConfiguration() clientConfiguration.setSignerOverride("AWSS3V4SignerType") val minioHost: String = Option(System.getenv("BLOBSTORE_MINIO_HOST")).getOrElse("minio-container") val minioPort: String = Option(System.getenv("BLOBSTORE_MINIO_PORT")).getOrElse("9000") private val client: AmazonS3 = AmazonS3ClientBuilder.standard() .withEndpointConfiguration(new AwsClientBuilder.EndpointConfiguration( s"http://$minioHost:$minioPort", Regions.US_EAST_1.name())) .withPathStyleAccessEnabled(true) .withClientConfiguration(clientConfiguration) .withCredentials(new AWSStaticCredentialsProvider(credentials)) .build() private val transferManager: TransferManager = TransferManagerBuilder.standard() .withS3Client(client) .build() override val store: Store[IO] = new S3Store[IO](transferManager, blocker = blocker) override val root: String = "blobstore-test-bucket" override def beforeAll(): Unit = { super.beforeAll() try { client.createBucket(root) } catch { case e: com.amazonaws.services.s3.model.AmazonS3Exception if e.getMessage.contains("BucketAlreadyOwnedByYou") => // noop } () } override def afterAll(): Unit = { super.afterAll() try { client.shutdown() } catch { case _: Throwable => } } }
Example 23
Source File: Credentials.scala From spark-select with Apache License 2.0 | 5 votes |
package io.minio.spark.select import java.net.URI // For BasicAWSCredentials import com.amazonaws.auth.AWSCredentials import com.amazonaws.auth.AWSCredentialsProvider import com.amazonaws.auth.BasicAWSCredentials import com.amazonaws.auth.BasicSessionCredentials import com.amazonaws.auth.DefaultAWSCredentialsProviderChain import org.apache.hadoop.conf.Configuration private[spark] object Credentials { private def staticCredentialsProvider(credentials: AWSCredentials): AWSCredentialsProvider = { new AWSCredentialsProvider { override def getCredentials: AWSCredentials = credentials override def refresh(): Unit = {} } } def load(location: Option[String], hadoopConfiguration: Configuration): AWSCredentialsProvider = { val uri = new URI(location.getOrElse("")) val uriScheme = uri.getScheme uriScheme match { case "s3" | "s3a" => // This matches what S3A does, with one exception: we don't // support anonymous credentials. First, try to parse from URI: Option(uri.getUserInfo).flatMap { userInfo => if (userInfo.contains(":")) { val Array(accessKey, secretKey) = userInfo.split(":") Some(staticCredentialsProvider(new BasicAWSCredentials(accessKey, secretKey))) } else { None } }.orElse { val accessKey = hadoopConfiguration.get(s"fs.s3a.access.key", null) val secretKey = hadoopConfiguration.get(s"fs.s3a.secret.key", null) val sessionToken = hadoopConfiguration.get(s"fs.s3a.session.token", null) if (accessKey != null && secretKey != null) { if (sessionToken != null) { Some(staticCredentialsProvider(new BasicSessionCredentials(accessKey, secretKey, sessionToken))) } else { Some(staticCredentialsProvider(new BasicAWSCredentials(accessKey, secretKey))) } } else { None } }.getOrElse { // Finally, fall back on the instance profile provider new DefaultAWSCredentialsProviderChain() } case other => throw new IllegalArgumentException(s"Unrecognized scheme $other; expected s3, or s3a") } } }
Example 24
Source File: V1DaxClientBuilderUtils.scala From akka-persistence-dynamodb with Apache License 2.0 | 5 votes |
package com.github.j5ik2o.akka.persistence.dynamodb.utils import com.amazon.dax.client.dynamodbv2.{ AmazonDaxAsyncClientBuilder, AmazonDaxClientBuilder } import com.amazonaws.auth.{ AWSStaticCredentialsProvider, BasicAWSCredentials } import com.amazonaws.services.dynamodbv2.{ AmazonDynamoDB, AmazonDynamoDBAsync } import com.github.j5ik2o.akka.persistence.dynamodb.config.client.DynamoDBClientConfig object V1DaxClientBuilderUtils { def setupSync(dynamoDBClientConfig: DynamoDBClientConfig): AmazonDaxClientBuilder = { val cc = V1DaxClientConfigUtils.setup(dynamoDBClientConfig) val builder = AmazonDaxClientBuilder.standard().withClientConfiguration(cc) (dynamoDBClientConfig.accessKeyId, dynamoDBClientConfig.secretAccessKey) match { case (Some(a), Some(s)) => builder.setCredentials( new AWSStaticCredentialsProvider(new BasicAWSCredentials(a, s)) ) case _ => } dynamoDBClientConfig.region.foreach(builder.setRegion) dynamoDBClientConfig.endpoint.foreach { v => builder.setEndpointConfiguration(v.split(","): _*) } builder } def setupAsync(dynamoDBClientConfig: DynamoDBClientConfig): AmazonDaxAsyncClientBuilder = { val cc = V1DaxClientConfigUtils.setup(dynamoDBClientConfig) val builder = AmazonDaxAsyncClientBuilder.standard().withClientConfiguration(cc) (dynamoDBClientConfig.accessKeyId, dynamoDBClientConfig.secretAccessKey) match { case (Some(a), Some(s)) => builder.setCredentials( new AWSStaticCredentialsProvider(new BasicAWSCredentials(a, s)) ) case _ => } dynamoDBClientConfig.region.foreach(builder.setRegion) dynamoDBClientConfig.endpoint.foreach { v => builder.setEndpointConfiguration(v.split(","): _*) } builder } }